From dc418a55298e853ef8b84ff6d6f02fb463a8124f Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Tue, 13 Aug 2024 16:15:15 -0400 Subject: [PATCH 01/19] initial support for agent SpanConcentrator wip --- ddtrace/tracer/civisibility_transport.go | 3 +- ddtrace/tracer/option.go | 21 +- ddtrace/tracer/span.go | 46 +-- ddtrace/tracer/span_test.go | 68 ++-- ddtrace/tracer/stats.go | 252 +++---------- ddtrace/tracer/stats_payload.go | 56 --- ddtrace/tracer/stats_payload_msgp.go | 450 ----------------------- ddtrace/tracer/stats_test.go | 203 +++++----- ddtrace/tracer/tracer_test.go | 20 +- ddtrace/tracer/transport.go | 6 +- go.mod | 114 +++--- go.sum | 268 +++++++++----- internal/apps/go.mod | 28 +- internal/apps/go.sum | 13 + internal/exectracetest/go.mod | 28 +- internal/exectracetest/go.sum | 12 + 16 files changed, 516 insertions(+), 1072 deletions(-) delete mode 100644 ddtrace/tracer/stats_payload.go delete mode 100644 ddtrace/tracer/stats_payload_msgp.go diff --git a/ddtrace/tracer/civisibility_transport.go b/ddtrace/tracer/civisibility_transport.go index db64b5d73d..dbbd10d3e7 100644 --- a/ddtrace/tracer/civisibility_transport.go +++ b/ddtrace/tracer/civisibility_transport.go @@ -16,6 +16,7 @@ import ( "strconv" "strings" + pb "github.com/DataDog/datadog-agent/pkg/proto/pbgo/trace" "gopkg.in/DataDog/dd-trace-go.v1/internal" "gopkg.in/DataDog/dd-trace-go.v1/internal/civisibility/constants" "gopkg.in/DataDog/dd-trace-go.v1/internal/log" @@ -185,7 +186,7 @@ func (t *ciVisibilityTransport) send(p *payload) (body io.ReadCloser, err error) // Returns: // // An error indicating that stats are not supported. -func (t *ciVisibilityTransport) sendStats(*statsPayload) error { +func (t *ciVisibilityTransport) sendStats(*pb.ClientStatsPayload) error { // Stats are not supported by CI Visibility agentless / EVP proxy. return nil } diff --git a/ddtrace/tracer/option.go b/ddtrace/tracer/option.go index 55041e943c..870c93cf8d 100644 --- a/ddtrace/tracer/option.go +++ b/ddtrace/tracer/option.go @@ -23,6 +23,7 @@ import ( "time" "golang.org/x/mod/semver" + "gopkg.in/DataDog/dd-trace-go.v1/ddtrace" "gopkg.in/DataDog/dd-trace-go.v1/ddtrace/ext" "gopkg.in/DataDog/dd-trace-go.v1/internal" @@ -626,6 +627,12 @@ type agentFeatures struct { // featureFlags specifies all the feature flags reported by the trace-agent. featureFlags map[string]struct{} + + // peerTags specifies precursor tags to aggregate stats on when client stats is enabled + peerTags []string + + // defaultEnv is the trace-agent's default env, used for stats calculation if no env override is present + defaultEnv string } // HasFlag reports whether the agent has set the feat feature flag. @@ -651,12 +658,18 @@ func loadAgentFeatures(agentDisabled bool, agentURL *url.URL, httpClient *http.C return } defer resp.Body.Close() + type agentConfig struct { + defaultEnv string `json:"default_env"` + } type infoResponse struct { - Endpoints []string `json:"endpoints"` - ClientDropP0s bool `json:"client_drop_p0s"` - StatsdPort int `json:"statsd_port"` - FeatureFlags []string `json:"feature_flags"` + Endpoints []string `json:"endpoints"` + ClientDropP0s bool `json:"client_drop_p0s"` + StatsdPort int `json:"statsd_port"` + FeatureFlags []string `json:"feature_flags"` + PeerTags []string `json:"peer_tags"` + Config agentConfig `json:"config"` } + var info infoResponse if err := json.NewDecoder(resp.Body).Decode(&info); err != nil { log.Error("Decoding features: %v", err) diff --git a/ddtrace/tracer/span.go b/ddtrace/tracer/span.go index 323003e23a..401f41ec4d 100644 --- a/ddtrace/tracer/span.go +++ b/ddtrace/tracer/span.go @@ -11,7 +11,6 @@ import ( "context" "encoding/base64" "fmt" - "math" "os" "reflect" "runtime" @@ -33,9 +32,10 @@ import ( "gopkg.in/DataDog/dd-trace-go.v1/internal/samplernames" "gopkg.in/DataDog/dd-trace-go.v1/internal/traceprof" - "github.com/DataDog/datadog-agent/pkg/obfuscate" "github.com/tinylib/msgp/msgp" "golang.org/x/xerrors" + + "github.com/DataDog/datadog-agent/pkg/obfuscate" ) type ( @@ -550,13 +550,17 @@ func (s *span) finish(finishTime int64) { return } // we have an active tracer + // todo: no need to check for shouldCompute if t.config.canComputeStats() && shouldComputeStats(s) { - // the agent supports computed stats - select { - case t.stats.In <- newAggregableSpan(s, t.obfuscator): - // ok - default: - log.Error("Stats channel full, disregarding span.") + statSpan, shouldCalc := t.stats.newAggregableSpan(s, t.obfuscator) + if shouldCalc { + // the agent supports computed stats + select { + case t.stats.In <- statSpan: + // ok + default: + log.Error("Stats channel full, disregarding span.") + } } } if t.config.canDropP0s() { @@ -591,32 +595,6 @@ func (s *span) finish(finishTime int64) { } } -// newAggregableSpan creates a new summary for the span s, within an application -// version version. -func newAggregableSpan(s *span, obfuscator *obfuscate.Obfuscator) *aggregableSpan { - var statusCode uint32 - if sc, ok := s.Meta["http.status_code"]; ok && sc != "" { - if c, err := strconv.Atoi(sc); err == nil && c > 0 && c <= math.MaxInt32 { - statusCode = uint32(c) - } - } - key := aggregation{ - Name: s.Name, - Resource: obfuscatedResource(obfuscator, s.Type, s.Resource), - Service: s.Service, - Type: s.Type, - Synthetics: strings.HasPrefix(s.Meta[keyOrigin], "synthetics"), - StatusCode: statusCode, - } - return &aggregableSpan{ - key: key, - Start: s.Start, - Duration: s.Duration, - TopLevel: s.Metrics[keyTopLevel] == 1, - Error: s.Error, - } -} - // textNonParsable specifies the text that will be assigned to resources for which the resource // can not be parsed due to an obfuscation error. const textNonParsable = "Non-parsable SQL query" diff --git a/ddtrace/tracer/span_test.go b/ddtrace/tracer/span_test.go index 95b1460ac0..ddf2337ef0 100644 --- a/ddtrace/tracer/span_test.go +++ b/ddtrace/tracer/span_test.go @@ -22,7 +22,6 @@ import ( "gopkg.in/DataDog/dd-trace-go.v1/internal/samplernames" "gopkg.in/DataDog/dd-trace-go.v1/internal/traceprof" - "github.com/DataDog/datadog-agent/pkg/obfuscate" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) @@ -165,38 +164,41 @@ func TestShouldComputeStats(t *testing.T) { } } -func TestNewAggregableSpan(t *testing.T) { - t.Run("obfuscating", func(t *testing.T) { - o := obfuscate.NewObfuscator(obfuscate.Config{}) - aggspan := newAggregableSpan(&span{ - Name: "name", - Resource: "SELECT * FROM table WHERE password='secret'", - Service: "service", - Type: "sql", - }, o) - assert.Equal(t, aggregation{ - Name: "name", - Type: "sql", - Resource: "SELECT * FROM table WHERE password = ?", - Service: "service", - }, aggspan.key) - }) - - t.Run("nil-obfuscator", func(t *testing.T) { - aggspan := newAggregableSpan(&span{ - Name: "name", - Resource: "SELECT * FROM table WHERE password='secret'", - Service: "service", - Type: "sql", - }, nil) - assert.Equal(t, aggregation{ - Name: "name", - Type: "sql", - Resource: "SELECT * FROM table WHERE password='secret'", - Service: "service", - }, aggspan.key) - }) -} +// +//func TestNewAggregableSpan(t *testing.T) { +// c := newConcentrator(&config{}, 1) +// t.Run("obfuscating", func(t *testing.T) { +// o := obfuscate.NewObfuscator(obfuscate.Config{}) +// aggspan, _ := c.newAggregableSpan(&span{ +// Name: "name", +// Resource: "SELECT * FROM table WHERE password='secret'", +// Service: "service", +// Type: "sql", +// }, o) +// assert.Equal(t, "SELECT * FROM table WHERE password = ?", aggspan.) +// assert.Equal(t, aggregation{ +// Name: "name", +// Type: "sql", +// Resource: , +// Service: "service", +// }, aggspan.key) +// }) +// +// t.Run("nil-obfuscator", func(t *testing.T) { +// aggspan := newAggregableSpan(&span{ +// Name: "name", +// Resource: "SELECT * FROM table WHERE password='secret'", +// Service: "service", +// Type: "sql", +// }, nil) +// assert.Equal(t, aggregation{ +// Name: "name", +// Type: "sql", +// Resource: "SELECT * FROM table WHERE password='secret'", +// Service: "service", +// }, aggspan.key) +// }) +//} func TestSpanFinishWithTime(t *testing.T) { assert := assert.New(t) diff --git a/ddtrace/tracer/stats.go b/ddtrace/tracer/stats.go index 720a2a0230..7a745f5a3f 100644 --- a/ddtrace/tracer/stats.go +++ b/ddtrace/tracer/stats.go @@ -12,26 +12,14 @@ import ( "sync/atomic" "time" + "github.com/DataDog/datadog-agent/pkg/obfuscate" + "github.com/DataDog/datadog-agent/pkg/trace/stats" "gopkg.in/DataDog/dd-trace-go.v1/internal" "gopkg.in/DataDog/dd-trace-go.v1/internal/log" "github.com/DataDog/datadog-go/v5/statsd" - "github.com/DataDog/sketches-go/ddsketch" - "google.golang.org/protobuf/proto" ) -// aggregableSpan holds necessary information about a span that can be used to -// aggregate statistics in a bucket. -type aggregableSpan struct { - // key specifies the aggregation key under which this span can be placed into - // grouped inside a bucket. - key aggregation - - Start, Duration int64 - Error int32 - TopLevel bool -} - // defaultStatsBucketSize specifies the default span of time that will be // covered in one stats bucket. var defaultStatsBucketSize = (10 * time.Second).Nanoseconds() @@ -43,18 +31,15 @@ type concentrator struct { // In specifies the channel to be used for feeding data to the concentrator. // In order for In to have a consumer, the concentrator must be started using // a call to Start. - In chan *aggregableSpan - - // mu guards below fields - mu sync.Mutex - - // buckets maintains a set of buckets, where the map key represents - // the starting point in time of that bucket, in nanoseconds. - buckets map[int64]*rawBucket + In chan *stats.StatSpan // stopped reports whether the concentrator is stopped (when non-zero) stopped uint32 + spanConcentrator *stats.SpanConcentrator + + aggregationKey stats.PayloadAggregationKey + wg sync.WaitGroup // waits for any active goroutines bucketSize int64 // the size of a bucket in nanoseconds stop chan struct{} // closing this channel triggers shutdown @@ -65,12 +50,30 @@ type concentrator struct { // newConcentrator creates a new concentrator using the given tracer // configuration c. It creates buckets of bucketSize nanoseconds duration. func newConcentrator(c *config, bucketSize int64) *concentrator { + sCfg := &stats.SpanConcentratorConfig{ + ComputeStatsBySpanKind: false, + BucketInterval: defaultStatsBucketSize, + } + env := c.agent.defaultEnv + if c.env != "" { + env = c.env + } + aggKey := stats.PayloadAggregationKey{ + Hostname: c.hostname, + Env: env, + Version: c.version, + ContainerID: "", //todo: verify these should be empty + GitCommitSha: "", + ImageTag: "", + } + spanConcentrator := stats.NewSpanConcentrator(sCfg, time.Now()) return &concentrator{ - In: make(chan *aggregableSpan, 10000), - bucketSize: bucketSize, - stopped: 1, - buckets: make(map[int64]*rawBucket), - cfg: c, + In: make(chan *stats.StatSpan, 10000), + bucketSize: bucketSize, + stopped: 1, + cfg: c, + aggregationKey: aggKey, + spanConcentrator: spanConcentrator, } } @@ -135,18 +138,14 @@ func (c *concentrator) runIngester() { } } -// add adds s into the concentrator's internal stats buckets. -func (c *concentrator) add(s *aggregableSpan) { - c.mu.Lock() - defer c.mu.Unlock() +func (c *concentrator) newAggregableSpan(s *span, obfuscator *obfuscate.Obfuscator) (*stats.StatSpan, bool) { + return c.spanConcentrator.NewStatSpan(s.Service, obfuscatedResource(obfuscator, s.Type, s.Resource), + s.Name, s.Type, s.ParentID, s.Start, s.Duration, s.Error, s.Meta, s.Metrics, c.cfg.agent.peerTags) +} - btime := alignTs(s.Start+s.Duration, c.bucketSize) - b, ok := c.buckets[btime] - if !ok { - b = newRawBucket(uint64(btime), c.bucketSize) - c.buckets[btime] = b - } - b.handleSpan(s) +// add adds s into the concentrator's internal stats buckets. +func (c *concentrator) add(s *stats.StatSpan) { + c.spanConcentrator.AddSpan(s, c.aggregationKey, "", nil, "") //todo: origin? } // Stop stops the concentrator and blocks until the operation completes. @@ -177,175 +176,22 @@ const ( // flushAndSend flushes all the stats buckets with the given timestamp and sends them using the transport specified in // the concentrator config. The current bucket is only included if includeCurrent is true, such as during shutdown. func (c *concentrator) flushAndSend(timenow time.Time, includeCurrent bool) { - sp := func() statsPayload { - c.mu.Lock() - defer c.mu.Unlock() - now := timenow.UnixNano() - sp := statsPayload{ - Hostname: c.cfg.hostname, - Env: c.cfg.env, - Version: c.cfg.version, - Stats: make([]statsBucket, 0, len(c.buckets)), - } - for ts, srb := range c.buckets { - if !includeCurrent && ts > now-c.bucketSize { - // do not flush the current bucket - continue - } - log.Debug("Flushing bucket %d", ts) - sp.Stats = append(sp.Stats, srb.Export()) - delete(c.buckets, ts) - } - return sp - }() + csps := c.spanConcentrator.Flush(timenow.UnixNano(), includeCurrent) - if len(sp.Stats) == 0 { + if len(csps) == 0 { // nothing to flush return } - c.statsd().Incr("datadog.tracer.stats.flush_payloads", nil, 1) - c.statsd().Incr("datadog.tracer.stats.flush_buckets", nil, float64(len(sp.Stats))) - if err := c.cfg.transport.sendStats(&sp); err != nil { - c.statsd().Incr("datadog.tracer.stats.flush_errors", nil, 1) - log.Error("Error sending stats payload: %v", err) - } -} - -// aggregation specifies a uniquely identifiable key under which a certain set -// of stats are grouped inside a bucket. -type aggregation struct { - Name string - Type string - Resource string - Service string - StatusCode uint32 - Synthetics bool -} - -type rawBucket struct { - start, duration uint64 - data map[aggregation]*rawGroupedStats -} - -func newRawBucket(btime uint64, bsize int64) *rawBucket { - return &rawBucket{ - start: btime, - duration: uint64(bsize), - data: make(map[aggregation]*rawGroupedStats), - } -} - -func (sb *rawBucket) handleSpan(s *aggregableSpan) { - gs, ok := sb.data[s.key] - if !ok { - gs = newRawGroupedStats() - sb.data[s.key] = gs - } - if s.TopLevel { - gs.topLevelHits++ - } - gs.hits++ - if s.Error != 0 { - gs.errors++ - } - gs.duration += uint64(s.Duration) - // alter resolution of duration distro - trundur := nsTimestampToFloat(s.Duration) - if s.Error != 0 { - gs.errDistribution.Add(trundur) - } else { - gs.okDistribution.Add(trundur) - } -} - -// Export transforms a RawBucket into a statsBucket, typically used -// before communicating data to the API, as RawBucket is the internal -// type while statsBucket is the public, shared one. -func (sb *rawBucket) Export() statsBucket { - csb := statsBucket{ - Start: sb.start, - Duration: sb.duration, - Stats: make([]groupedStats, len(sb.data)), - } - for k, v := range sb.data { - b, err := v.export(k) - if err != nil { - log.Error("Could not export stats bucket: %v.", err) - continue + c.statsd().Incr("datadog.tracer.stats.flush_payloads", nil, float64(len(csps))) + flushedBuckets := 0 + // Given we use a constant PayloadAggregationKey there should only ever be 1 of these, but to be forward + // compatible in case this ever changes we can just iterate through all of them. + for _, csp := range csps { + flushedBuckets += len(csp.Stats) + if err := c.cfg.transport.sendStats(csp); err != nil { + c.statsd().Incr("datadog.tracer.stats.flush_errors", nil, 1) + log.Error("Error sending stats payload: %v", err) } - csb.Stats = append(csb.Stats, b) - } - return csb -} - -type rawGroupedStats struct { - hits uint64 - topLevelHits uint64 - errors uint64 - duration uint64 - okDistribution *ddsketch.DDSketch - errDistribution *ddsketch.DDSketch -} - -func newRawGroupedStats() *rawGroupedStats { - const ( - // relativeAccuracy is the value accuracy we have on the percentiles. For example, we can - // say that p99 is 100ms +- 1ms - relativeAccuracy = 0.01 - // maxNumBins is the maximum number of bins of the ddSketch we use to store percentiles. - // It can affect relative accuracy, but in practice, 2048 bins is enough to have 1% relative accuracy from - // 80 micro second to 1 year: http://www.vldb.org/pvldb/vol12/p2195-masson.pdf - maxNumBins = 2048 - ) - okSketch, err := ddsketch.LogCollapsingLowestDenseDDSketch(relativeAccuracy, maxNumBins) - if err != nil { - log.Error("Error when creating ddsketch: %v", err) - } - errSketch, err := ddsketch.LogCollapsingLowestDenseDDSketch(relativeAccuracy, maxNumBins) - if err != nil { - log.Error("Error when creating ddsketch: %v", err) - } - return &rawGroupedStats{ - okDistribution: okSketch, - errDistribution: errSketch, - } -} - -func (s *rawGroupedStats) export(k aggregation) (groupedStats, error) { - msg := s.okDistribution.ToProto() - okSummary, err := proto.Marshal(msg) - if err != nil { - return groupedStats{}, err - } - msg = s.errDistribution.ToProto() - errSummary, err := proto.Marshal(msg) - if err != nil { - return groupedStats{}, err - } - return groupedStats{ - Service: k.Service, - Name: k.Name, - Resource: k.Resource, - HTTPStatusCode: k.StatusCode, - Type: k.Type, - Hits: s.hits, - Errors: s.errors, - Duration: s.duration, - TopLevelHits: s.topLevelHits, - OkSummary: okSummary, - ErrorSummary: errSummary, - Synthetics: k.Synthetics, - }, nil -} - -// nsTimestampToFloat converts a nanosec timestamp into a float nanosecond timestamp truncated to a fixed precision -func nsTimestampToFloat(ns int64) float64 { - // 10 bits precision (any value will be +/- 1/1024) - const roundMask int64 = 1 << 10 - var shift uint - for ns > roundMask { - ns = ns >> 1 - shift++ } - return float64(ns << shift) + c.statsd().Incr("datadog.tracer.stats.flush_buckets", nil, float64(flushedBuckets)) } diff --git a/ddtrace/tracer/stats_payload.go b/ddtrace/tracer/stats_payload.go deleted file mode 100644 index 35a68b46b9..0000000000 --- a/ddtrace/tracer/stats_payload.go +++ /dev/null @@ -1,56 +0,0 @@ -// Unless explicitly stated otherwise all files in this repository are licensed -// under the Apache License Version 2.0. -// This product includes software developed at Datadog (https://www.datadoghq.com/). -// Copyright 2016 Datadog, Inc. - -//go:generate msgp -unexported -marshal=false -o=stats_payload_msgp.go -tests=false - -package tracer - -// statsPayload specifies information about client computed stats and is encoded -// to be sent to the agent. -type statsPayload struct { - // Hostname specifies the hostname of the application. - Hostname string - - // Env specifies the env. of the application, as defined by the user. - Env string - - // Version specifies the application version. - Version string - - // Stats holds all stats buckets computed within this payload. - Stats []statsBucket -} - -// statsBucket specifies a set of stats computed over a duration. -type statsBucket struct { - // Start specifies the beginning of this bucket. - Start uint64 - - // Duration specifies the duration of this bucket. - Duration uint64 - - // Stats contains a set of statistics computed for the duration of this bucket. - Stats []groupedStats -} - -// groupedStats contains a set of statistics grouped under various aggregation keys. -type groupedStats struct { - // These fields indicate the properties under which the stats were aggregated. - Service string `json:"service,omitempty"` - Name string `json:"name,omitempty"` - Resource string `json:"resource,omitempty"` - HTTPStatusCode uint32 `json:"HTTP_status_code,omitempty"` - Type string `json:"type,omitempty"` - DBType string `json:"DB_type,omitempty"` - - // These fields specify the stats for the above aggregation. - Hits uint64 `json:"hits,omitempty"` - Errors uint64 `json:"errors,omitempty"` - Duration uint64 `json:"duration,omitempty"` - OkSummary []byte `json:"okSummary,omitempty"` - ErrorSummary []byte `json:"errorSummary,omitempty"` - Synthetics bool `json:"synthetics,omitempty"` - TopLevelHits uint64 `json:"topLevelHits,omitempty"` -} diff --git a/ddtrace/tracer/stats_payload_msgp.go b/ddtrace/tracer/stats_payload_msgp.go deleted file mode 100644 index 7d15d036e7..0000000000 --- a/ddtrace/tracer/stats_payload_msgp.go +++ /dev/null @@ -1,450 +0,0 @@ -// Unless explicitly stated otherwise all files in this repository are licensed -// under the Apache License Version 2.0. -// This product includes software developed at Datadog (https://www.datadoghq.com/). -// Copyright 2016 Datadog, Inc. - -package tracer - -// NOTE: THIS FILE WAS PRODUCED BY THE -// MSGP CODE GENERATION TOOL (github.com/tinylib/msgp) -// DO NOT EDIT - -import ( - "github.com/tinylib/msgp/msgp" -) - -// DecodeMsg implements msgp.Decodable -func (z *groupedStats) DecodeMsg(dc *msgp.Reader) (err error) { - var field []byte - _ = field - var zb0001 uint32 - zb0001, err = dc.ReadMapHeader() - if err != nil { - return - } - for zb0001 > 0 { - zb0001-- - field, err = dc.ReadMapKeyPtr() - if err != nil { - return - } - switch msgp.UnsafeString(field) { - case "Service": - z.Service, err = dc.ReadString() - if err != nil { - return - } - case "Name": - z.Name, err = dc.ReadString() - if err != nil { - return - } - case "Resource": - z.Resource, err = dc.ReadString() - if err != nil { - return - } - case "HTTPStatusCode": - z.HTTPStatusCode, err = dc.ReadUint32() - if err != nil { - return - } - case "Type": - z.Type, err = dc.ReadString() - if err != nil { - return - } - case "DBType": - z.DBType, err = dc.ReadString() - if err != nil { - return - } - case "Hits": - z.Hits, err = dc.ReadUint64() - if err != nil { - return - } - case "Errors": - z.Errors, err = dc.ReadUint64() - if err != nil { - return - } - case "Duration": - z.Duration, err = dc.ReadUint64() - if err != nil { - return - } - case "OkSummary": - z.OkSummary, err = dc.ReadBytes(z.OkSummary) - if err != nil { - return - } - case "ErrorSummary": - z.ErrorSummary, err = dc.ReadBytes(z.ErrorSummary) - if err != nil { - return - } - case "Synthetics": - z.Synthetics, err = dc.ReadBool() - if err != nil { - return - } - case "TopLevelHits": - z.TopLevelHits, err = dc.ReadUint64() - if err != nil { - return - } - default: - err = dc.Skip() - if err != nil { - return - } - } - } - return -} - -// EncodeMsg implements msgp.Encodable -func (z *groupedStats) EncodeMsg(en *msgp.Writer) (err error) { - // map header, size 13 - // write "Service" - err = en.Append(0x8d, 0xa7, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65) - if err != nil { - return - } - err = en.WriteString(z.Service) - if err != nil { - return - } - // write "Name" - err = en.Append(0xa4, 0x4e, 0x61, 0x6d, 0x65) - if err != nil { - return - } - err = en.WriteString(z.Name) - if err != nil { - return - } - // write "Resource" - err = en.Append(0xa8, 0x52, 0x65, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65) - if err != nil { - return - } - err = en.WriteString(z.Resource) - if err != nil { - return - } - // write "HTTPStatusCode" - err = en.Append(0xae, 0x48, 0x54, 0x54, 0x50, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x43, 0x6f, 0x64, 0x65) - if err != nil { - return - } - err = en.WriteUint32(z.HTTPStatusCode) - if err != nil { - return - } - // write "Type" - err = en.Append(0xa4, 0x54, 0x79, 0x70, 0x65) - if err != nil { - return - } - err = en.WriteString(z.Type) - if err != nil { - return - } - // write "DBType" - err = en.Append(0xa6, 0x44, 0x42, 0x54, 0x79, 0x70, 0x65) - if err != nil { - return - } - err = en.WriteString(z.DBType) - if err != nil { - return - } - // write "Hits" - err = en.Append(0xa4, 0x48, 0x69, 0x74, 0x73) - if err != nil { - return - } - err = en.WriteUint64(z.Hits) - if err != nil { - return - } - // write "Errors" - err = en.Append(0xa6, 0x45, 0x72, 0x72, 0x6f, 0x72, 0x73) - if err != nil { - return - } - err = en.WriteUint64(z.Errors) - if err != nil { - return - } - // write "Duration" - err = en.Append(0xa8, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e) - if err != nil { - return - } - err = en.WriteUint64(z.Duration) - if err != nil { - return - } - // write "OkSummary" - err = en.Append(0xa9, 0x4f, 0x6b, 0x53, 0x75, 0x6d, 0x6d, 0x61, 0x72, 0x79) - if err != nil { - return - } - err = en.WriteBytes(z.OkSummary) - if err != nil { - return - } - // write "ErrorSummary" - err = en.Append(0xac, 0x45, 0x72, 0x72, 0x6f, 0x72, 0x53, 0x75, 0x6d, 0x6d, 0x61, 0x72, 0x79) - if err != nil { - return - } - err = en.WriteBytes(z.ErrorSummary) - if err != nil { - return - } - // write "Synthetics" - err = en.Append(0xaa, 0x53, 0x79, 0x6e, 0x74, 0x68, 0x65, 0x74, 0x69, 0x63, 0x73) - if err != nil { - return - } - err = en.WriteBool(z.Synthetics) - if err != nil { - return - } - // write "TopLevelHits" - err = en.Append(0xac, 0x54, 0x6f, 0x70, 0x4c, 0x65, 0x76, 0x65, 0x6c, 0x48, 0x69, 0x74, 0x73) - if err != nil { - return - } - err = en.WriteUint64(z.TopLevelHits) - if err != nil { - return - } - return -} - -// Msgsize returns an upper bound estimate of the number of bytes occupied by the serialized message -func (z *groupedStats) Msgsize() (s int) { - s = 1 + 8 + msgp.StringPrefixSize + len(z.Service) + 5 + msgp.StringPrefixSize + len(z.Name) + 9 + msgp.StringPrefixSize + len(z.Resource) + 15 + msgp.Uint32Size + 5 + msgp.StringPrefixSize + len(z.Type) + 7 + msgp.StringPrefixSize + len(z.DBType) + 5 + msgp.Uint64Size + 7 + msgp.Uint64Size + 9 + msgp.Uint64Size + 10 + msgp.BytesPrefixSize + len(z.OkSummary) + 13 + msgp.BytesPrefixSize + len(z.ErrorSummary) + 11 + msgp.BoolSize + 13 + msgp.Uint64Size - return -} - -// DecodeMsg implements msgp.Decodable -func (z *statsBucket) DecodeMsg(dc *msgp.Reader) (err error) { - var field []byte - _ = field - var zb0001 uint32 - zb0001, err = dc.ReadMapHeader() - if err != nil { - return - } - for zb0001 > 0 { - zb0001-- - field, err = dc.ReadMapKeyPtr() - if err != nil { - return - } - switch msgp.UnsafeString(field) { - case "Start": - z.Start, err = dc.ReadUint64() - if err != nil { - return - } - case "Duration": - z.Duration, err = dc.ReadUint64() - if err != nil { - return - } - case "Stats": - var zb0002 uint32 - zb0002, err = dc.ReadArrayHeader() - if err != nil { - return - } - if cap(z.Stats) >= int(zb0002) { - z.Stats = (z.Stats)[:zb0002] - } else { - z.Stats = make([]groupedStats, zb0002) - } - for za0001 := range z.Stats { - err = z.Stats[za0001].DecodeMsg(dc) - if err != nil { - return - } - } - default: - err = dc.Skip() - if err != nil { - return - } - } - } - return -} - -// EncodeMsg implements msgp.Encodable -func (z *statsBucket) EncodeMsg(en *msgp.Writer) (err error) { - // map header, size 3 - // write "Start" - err = en.Append(0x83, 0xa5, 0x53, 0x74, 0x61, 0x72, 0x74) - if err != nil { - return - } - err = en.WriteUint64(z.Start) - if err != nil { - return - } - // write "Duration" - err = en.Append(0xa8, 0x44, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e) - if err != nil { - return - } - err = en.WriteUint64(z.Duration) - if err != nil { - return - } - // write "Stats" - err = en.Append(0xa5, 0x53, 0x74, 0x61, 0x74, 0x73) - if err != nil { - return - } - err = en.WriteArrayHeader(uint32(len(z.Stats))) - if err != nil { - return - } - for za0001 := range z.Stats { - err = z.Stats[za0001].EncodeMsg(en) - if err != nil { - return - } - } - return -} - -// Msgsize returns an upper bound estimate of the number of bytes occupied by the serialized message -func (z *statsBucket) Msgsize() (s int) { - s = 1 + 6 + msgp.Uint64Size + 9 + msgp.Uint64Size + 6 + msgp.ArrayHeaderSize - for za0001 := range z.Stats { - s += z.Stats[za0001].Msgsize() - } - return -} - -// DecodeMsg implements msgp.Decodable -func (z *statsPayload) DecodeMsg(dc *msgp.Reader) (err error) { - var field []byte - _ = field - var zb0001 uint32 - zb0001, err = dc.ReadMapHeader() - if err != nil { - return - } - for zb0001 > 0 { - zb0001-- - field, err = dc.ReadMapKeyPtr() - if err != nil { - return - } - switch msgp.UnsafeString(field) { - case "Hostname": - z.Hostname, err = dc.ReadString() - if err != nil { - return - } - case "Env": - z.Env, err = dc.ReadString() - if err != nil { - return - } - case "Version": - z.Version, err = dc.ReadString() - if err != nil { - return - } - case "Stats": - var zb0002 uint32 - zb0002, err = dc.ReadArrayHeader() - if err != nil { - return - } - if cap(z.Stats) >= int(zb0002) { - z.Stats = (z.Stats)[:zb0002] - } else { - z.Stats = make([]statsBucket, zb0002) - } - for za0001 := range z.Stats { - err = z.Stats[za0001].DecodeMsg(dc) - if err != nil { - return - } - } - default: - err = dc.Skip() - if err != nil { - return - } - } - } - return -} - -// EncodeMsg implements msgp.Encodable -func (z *statsPayload) EncodeMsg(en *msgp.Writer) (err error) { - // map header, size 4 - // write "Hostname" - err = en.Append(0x84, 0xa8, 0x48, 0x6f, 0x73, 0x74, 0x6e, 0x61, 0x6d, 0x65) - if err != nil { - return - } - err = en.WriteString(z.Hostname) - if err != nil { - return - } - // write "Env" - err = en.Append(0xa3, 0x45, 0x6e, 0x76) - if err != nil { - return - } - err = en.WriteString(z.Env) - if err != nil { - return - } - // write "Version" - err = en.Append(0xa7, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e) - if err != nil { - return - } - err = en.WriteString(z.Version) - if err != nil { - return - } - // write "Stats" - err = en.Append(0xa5, 0x53, 0x74, 0x61, 0x74, 0x73) - if err != nil { - return - } - err = en.WriteArrayHeader(uint32(len(z.Stats))) - if err != nil { - return - } - for za0001 := range z.Stats { - err = z.Stats[za0001].EncodeMsg(en) - if err != nil { - return - } - } - return -} - -// Msgsize returns an upper bound estimate of the number of bytes occupied by the serialized message -func (z *statsPayload) Msgsize() (s int) { - s = 1 + 9 + msgp.StringPrefixSize + len(z.Hostname) + 4 + msgp.StringPrefixSize + len(z.Env) + 8 + msgp.StringPrefixSize + len(z.Version) + 6 + msgp.ArrayHeaderSize - for za0001 := range z.Stats { - s += z.Stats[za0001].Msgsize() - } - return -} diff --git a/ddtrace/tracer/stats_test.go b/ddtrace/tracer/stats_test.go index 56e3eb029d..5292e9230f 100644 --- a/ddtrace/tracer/stats_test.go +++ b/ddtrace/tracer/stats_test.go @@ -11,22 +11,10 @@ import ( "time" "github.com/stretchr/testify/assert" -) + "github.com/stretchr/testify/require" -// waitForBuckets reports whether concentrator c contains n buckets within a 5ms -// period. -func waitForBuckets(c *concentrator, n int) bool { - for i := 0; i < 5; i++ { - time.Sleep(time.Millisecond * timeMultiplicator) - c.mu.Lock() - if len(c.buckets) == n { - c.mu.Unlock() - return true - } - c.mu.Unlock() - } - return false -} + "github.com/DataDog/datadog-agent/pkg/trace/stats" +) func TestAlignTs(t *testing.T) { now := time.Now().UnixNano() @@ -36,33 +24,19 @@ func TestAlignTs(t *testing.T) { } func TestConcentrator(t *testing.T) { - key1 := aggregation{ - Name: "http.request", - } - ss1 := &aggregableSpan{ - key: key1, - Start: time.Now().UnixNano() + 2*defaultStatsBucketSize, - Duration: (2 * time.Second).Nanoseconds(), - } - key2 := aggregation{ - Name: "sql.query", - } - ss2 := &aggregableSpan{ - key: key2, - Start: time.Now().UnixNano() + 3*defaultStatsBucketSize, - Duration: (3 * time.Second).Nanoseconds(), - } + bucketSize := int64(500_000) - t.Run("new", func(t *testing.T) { - assert := assert.New(t) - cfg := &config{version: "1.2.3"} - c := newConcentrator(cfg, defaultStatsBucketSize) - assert.Equal(cap(c.In), 10000) - assert.Nil(c.stop) - assert.NotNil(c.buckets) - assert.Equal(c.cfg, cfg) - assert.EqualValues(atomic.LoadUint32(&c.stopped), 1) - }) + sc := stats.NewSpanConcentrator(&stats.SpanConcentratorConfig{BucketInterval: bucketSize}, time.Now()) + ss1, ok := sc.NewStatSpan("", "", "http.request", "", 0, + time.Now().UnixNano()+3*bucketSize, + 1, + 0, nil, map[string]float64{keyMeasured: 1}, nil) + require.True(t, ok) + ss2, ok := sc.NewStatSpan("", "", "sql.query", "", 0, + time.Now().UnixNano()+4*bucketSize, + 1, + 0, nil, map[string]float64{keyMeasured: 1}, nil) + require.True(t, ok) t.Run("start-stop", func(t *testing.T) { assert := assert.New(t) @@ -83,97 +57,94 @@ func TestConcentrator(t *testing.T) { assert.EqualValues(atomic.LoadUint32(&c.stopped), 1) }) - t.Run("valid", func(t *testing.T) { - c := newConcentrator(&config{}, defaultStatsBucketSize) - btime := alignTs(ss1.Start+ss1.Duration, defaultStatsBucketSize) - c.add(ss1) - assert.Len(t, c.buckets, 1) - b, ok := c.buckets[btime] - assert.True(t, ok) - assert.Equal(t, b.start, uint64(btime)) - assert.Equal(t, b.duration, uint64(defaultStatsBucketSize)) - }) - - t.Run("grouping", func(t *testing.T) { - c := newConcentrator(&config{}, defaultStatsBucketSize) - c.add(ss1) - c.add(ss1) - assert.Len(t, c.buckets, 1) - _, ok := c.buckets[alignTs(ss1.Start+ss1.Duration, defaultStatsBucketSize)] - assert.True(t, ok) - c.add(ss2) - assert.Len(t, c.buckets, 2) - _, ok = c.buckets[alignTs(ss2.Start+ss2.Duration, defaultStatsBucketSize)] - assert.True(t, ok) - }) - - t.Run("ingester", func(t *testing.T) { - transport := newDummyTransport() - c := newConcentrator(&config{transport: transport}, defaultStatsBucketSize) - c.Start() - assert.Len(t, c.buckets, 0) - c.In <- ss1 - if !waitForBuckets(c, 1) { - t.Fatal("sending to channel did not work") - } - c.Stop() - }) + //t.Run("valid", func(t *testing.T) { + // c := newConcentrator(&config{env: "someEnv"}, defaultStatsBucketSize) + // //btime := alignTs(ss1.Start+ss1.Duration, defaultStatsBucketSize) + // c.add(ss1) + // + // //assert.Len(t, c.buckets, 1) + // //b, ok := c.buckets[btime] + // //assert.True(t, ok) + // //assert.Equal(t, b.start, uint64(btime)) + // //assert.Equal(t, b.duration, uint64(defaultStatsBucketSize)) + //}) + //t.Run("grouping", func(t *testing.T) { + // c := newConcentrator(&config{}, defaultStatsBucketSize) + // c.add(ss1) + // c.add(ss1) + // assert.Len(t, c.buckets, 1) + // _, ok := c.buckets[alignTs(ss1.Start+ss1.Duration, defaultStatsBucketSize)] + // assert.True(t, ok) + // c.add(ss2) + // assert.Len(t, c.buckets, 2) + // _, ok = c.buckets[alignTs(ss2.Start+ss2.Duration, defaultStatsBucketSize)] + // assert.True(t, ok) + //}) + // + //t.Run("ingester", func(t *testing.T) { + // transport := newDummyTransport() + // c := newConcentrator(&config{transport: transport}, defaultStatsBucketSize) + // c.Start() + // assert.Len(t, c.buckets, 0) + // c.In <- ss1 + // if !waitForBuckets(c, 1) { + // t.Fatal("sending to channel did not work") + // } + // c.Stop() + //}) + // t.Run("flusher", func(t *testing.T) { t.Run("old", func(t *testing.T) { transport := newDummyTransport() - c := newConcentrator(&config{transport: transport}, 500000) + c := newConcentrator(&config{transport: transport, env: "someEnv"}, 500_000) assert.Len(t, transport.Stats(), 0) c.Start() - c.In <- &aggregableSpan{ - key: key2, - // Start must be older than latest bucket to get flushed - Start: time.Now().UnixNano() - 3*500000, - Duration: 1, - } - c.In <- &aggregableSpan{ - key: key2, - // Start must be older than latest bucket to get flushed - Start: time.Now().UnixNano() - 4*500000, - Duration: 1, - } + c.In <- ss1 time.Sleep(2 * time.Millisecond * timeMultiplicator) c.Stop() - assert.NotZero(t, transport.Stats()) + actualStats := transport.Stats() + assert.Len(t, actualStats, 1) + assert.Len(t, actualStats[0].Stats, 1) + assert.Len(t, actualStats[0].Stats[0].Stats, 1) + assert.Equal(t, "http.request", actualStats[0].Stats[0].Stats[0].Name) }) t.Run("recent", func(t *testing.T) { transport := newDummyTransport() - c := newConcentrator(&config{transport: transport}, 500000) + c := newConcentrator(&config{transport: transport, env: "someEnv"}, (10 * time.Second).Nanoseconds()) assert.Len(t, transport.Stats(), 0) c.Start() - c.In <- &aggregableSpan{ - key: key2, - Start: time.Now().UnixNano() + 5*500000, - Duration: 1, - } - c.In <- &aggregableSpan{ - key: key1, - Start: time.Now().UnixNano() + 6*500000, - Duration: 1, - } + c.In <- ss1 + c.In <- ss2 c.Stop() - assert.NotEmpty(t, transport.Stats()) - }) - - // stats should be sent if the concentrator is stopped - t.Run("stop", func(t *testing.T) { - transport := newDummyTransport() - c := newConcentrator(&config{transport: transport}, 500000) - assert.Len(t, transport.Stats(), 0) - c.Start() - c.In <- &aggregableSpan{ - key: key1, - Start: time.Now().UnixNano(), - Duration: 1, + actualStats := transport.Stats() + assert.Len(t, actualStats, 1) + assert.Len(t, actualStats[0].Stats, 1) + assert.Len(t, actualStats[0].Stats[0].Stats, 2) + names := map[string]struct{}{} + for _, stat := range actualStats[0].Stats[0].Stats { + names[stat.Name] = struct{}{} } - c.Stop() - assert.NotEmpty(t, transport.Stats()) + assert.Len(t, names, 2) + assert.NotNil(t, names["http.request"]) + assert.NotNil(t, names["potato"]) }) }) + // + // // stats should be sent if the concentrator is stopped + // t.Run("stop", func(t *testing.T) { + // transport := newDummyTransport() + // c := newConcentrator(&config{transport: transport}, 500000) + // assert.Len(t, transport.Stats(), 0) + // c.Start() + // c.In <- &aggregableSpan{ + // key: key1, + // Start: time.Now().UnixNano(), + // Duration: 1, + // } + // c.Stop() + // assert.NotEmpty(t, transport.Stats()) + // }) + //}) } diff --git a/ddtrace/tracer/tracer_test.go b/ddtrace/tracer/tracer_test.go index 19835db105..99fdf31422 100644 --- a/ddtrace/tracer/tracer_test.go +++ b/ddtrace/tracer/tracer_test.go @@ -24,6 +24,7 @@ import ( "testing" "time" + pb "github.com/DataDog/datadog-agent/pkg/proto/pbgo/trace" "gopkg.in/DataDog/dd-trace-go.v1/ddtrace" "gopkg.in/DataDog/dd-trace-go.v1/ddtrace/ext" "gopkg.in/DataDog/dd-trace-go.v1/ddtrace/internal" @@ -2167,7 +2168,7 @@ func startTestTracer(t testing.TB, opts ...StartOption) (trc *tracer, transport type dummyTransport struct { sync.RWMutex traces spanLists - stats []*statsPayload + stats []*pb.ClientStatsPayload } func newDummyTransport() *dummyTransport { @@ -2180,14 +2181,14 @@ func (t *dummyTransport) Len() int { return len(t.traces) } -func (t *dummyTransport) sendStats(p *statsPayload) error { +func (t *dummyTransport) sendStats(p *pb.ClientStatsPayload) error { t.Lock() t.stats = append(t.stats, p) t.Unlock() return nil } -func (t *dummyTransport) Stats() []*statsPayload { +func (t *dummyTransport) Stats() []*pb.ClientStatsPayload { t.RLock() defer t.RUnlock() return t.stats @@ -2324,7 +2325,7 @@ func TestFlush(t *testing.T) { tr.statsd = ts transport := newDummyTransport() - c := newConcentrator(&config{transport: transport}, defaultStatsBucketSize) + c := newConcentrator(&config{transport: transport, env: "someEnv"}, defaultStatsBucketSize) tr.stats = c c.Start() defer c.Stop() @@ -2344,15 +2345,16 @@ loop: time.Sleep(time.Millisecond) } } - as := &aggregableSpan{ - key: aggregation{ - Name: "http.request", - }, + s := &span{ + Name: "http.request", // Start must be older than latest bucket to get flushed Start: time.Now().UnixNano() - 3*defaultStatsBucketSize, Duration: 1, + Metrics: map[string]float64{keyMeasured: 1}, } - c.add(as) + statSpan, ok := c.newAggregableSpan(s, tr.obfuscator) + assert.True(t, ok) + c.add(statSpan) assert.Len(t, tw.Flushed(), 0) assert.Zero(t, ts.Flushed()) diff --git a/ddtrace/tracer/transport.go b/ddtrace/tracer/transport.go index c6a900c055..bf26c37332 100644 --- a/ddtrace/tracer/transport.go +++ b/ddtrace/tracer/transport.go @@ -17,6 +17,8 @@ import ( "sync/atomic" "time" + pb "github.com/DataDog/datadog-agent/pkg/proto/pbgo/trace" + traceinternal "gopkg.in/DataDog/dd-trace-go.v1/ddtrace/internal" "gopkg.in/DataDog/dd-trace-go.v1/internal" "gopkg.in/DataDog/dd-trace-go.v1/internal/version" @@ -68,7 +70,7 @@ type transport interface { // It returns a non-nil response body when no error occurred. send(p *payload) (body io.ReadCloser, err error) // sendStats sends the given stats payload to the agent. - sendStats(s *statsPayload) error + sendStats(s *pb.ClientStatsPayload) error // endpoint returns the URL to which the transport will send traces. endpoint() string } @@ -110,7 +112,7 @@ func newHTTPTransport(url string, client *http.Client) *httpTransport { } } -func (t *httpTransport) sendStats(p *statsPayload) error { +func (t *httpTransport) sendStats(p *pb.ClientStatsPayload) error { var buf bytes.Buffer if err := msgp.Encode(&buf, p); err != nil { return err diff --git a/go.mod b/go.mod index 4d111b3e3a..b150ff251e 100644 --- a/go.mod +++ b/go.mod @@ -1,14 +1,16 @@ module gopkg.in/DataDog/dd-trace-go.v1 -go 1.21 +go 1.21.0 require ( - cloud.google.com/go/pubsub v1.33.0 + cloud.google.com/go/pubsub v1.36.1 github.com/99designs/gqlgen v0.17.36 github.com/DataDog/appsec-internal-go v1.7.0 - github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 - github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 - github.com/DataDog/datadog-go/v5 v5.3.0 + github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 + github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 + github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 + github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 + github.com/DataDog/datadog-go/v5 v5.5.0 github.com/DataDog/go-libddwaf/v3 v3.3.0 github.com/DataDog/gostackparse v0.7.0 github.com/DataDog/sketches-go v1.4.5 @@ -50,10 +52,10 @@ require ( github.com/go-sql-driver/mysql v1.6.0 github.com/gocql/gocql v0.0.0-20220224095938-0eacd3183625 github.com/gofiber/fiber/v2 v2.52.5 - github.com/golang/protobuf v1.5.3 + github.com/golang/protobuf v1.5.4 github.com/gomodule/redigo v1.8.9 github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b - github.com/google/uuid v1.5.0 + github.com/google/uuid v1.6.0 github.com/gorilla/mux v1.8.0 github.com/graph-gophers/graphql-go v1.5.0 github.com/graphql-go/graphql v0.8.1 @@ -73,7 +75,7 @@ require ( github.com/mattn/go-sqlite3 v1.14.18 github.com/microsoft/go-mssqldb v0.21.0 github.com/miekg/dns v1.1.55 - github.com/mitchellh/mapstructure v1.5.0 + github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c github.com/opentracing/opentracing-go v1.2.0 github.com/redis/go-redis/v9 v9.1.0 github.com/richardartoul/molecule v1.0.1-0.20240531184615-7ca0df43c0b3 @@ -92,19 +94,19 @@ require ( github.com/vektah/gqlparser/v2 v2.5.16 github.com/zenazn/goji v1.0.1 go.mongodb.org/mongo-driver v1.12.1 - go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.44.0 - go.opentelemetry.io/otel v1.20.0 - go.opentelemetry.io/otel/trace v1.20.0 + go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.49.0 + go.opentelemetry.io/otel v1.27.0 + go.opentelemetry.io/otel/trace v1.27.0 go.uber.org/atomic v1.11.0 - golang.org/x/mod v0.14.0 - golang.org/x/net v0.23.0 - golang.org/x/oauth2 v0.9.0 - golang.org/x/sys v0.20.0 - golang.org/x/time v0.3.0 + golang.org/x/mod v0.20.0 + golang.org/x/net v0.27.0 + golang.org/x/oauth2 v0.18.0 + golang.org/x/sys v0.23.0 + golang.org/x/time v0.6.0 golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 - google.golang.org/api v0.128.0 - google.golang.org/grpc v1.57.1 - google.golang.org/protobuf v1.33.0 + google.golang.org/api v0.169.0 + google.golang.org/grpc v1.64.0 + google.golang.org/protobuf v1.34.2 gopkg.in/jinzhu/gorm.v1 v1.9.2 gopkg.in/olivere/elastic.v3 v3.0.75 gopkg.in/olivere/elastic.v5 v5.0.84 @@ -112,17 +114,21 @@ require ( gorm.io/driver/postgres v1.4.6 gorm.io/driver/sqlserver v1.4.2 gorm.io/gorm v1.25.3 - k8s.io/apimachinery v0.23.17 + k8s.io/apimachinery v0.25.5 k8s.io/client-go v0.23.17 modernc.org/sqlite v1.28.0 ) require ( - cloud.google.com/go v0.110.7 // indirect - cloud.google.com/go/compute v1.23.0 // indirect + cloud.google.com/go v0.112.1 // indirect + cloud.google.com/go/compute v1.25.1 // indirect cloud.google.com/go/compute/metadata v0.2.3 // indirect - cloud.google.com/go/iam v1.1.2 // indirect - github.com/DataDog/go-tuf v1.0.2-0.5.2 // indirect + cloud.google.com/go/iam v1.1.6 // indirect + github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 // indirect + github.com/DataDog/go-sqllexer v0.0.13 // indirect + github.com/DataDog/go-tuf v1.1.0-0.5.2 // indirect + github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0 // indirect github.com/Microsoft/go-winio v0.6.1 // indirect github.com/agnivade/levenshtein v1.1.1 // indirect github.com/andybalholm/brotli v1.0.6 // indirect @@ -144,9 +150,10 @@ require ( github.com/aws/aws-sdk-go-v2/service/sts v1.18.9 // indirect github.com/bytedance/sonic v1.10.0 // indirect github.com/cenkalti/backoff/v3 v3.2.2 // indirect - github.com/cespare/xxhash/v2 v2.2.0 // indirect + github.com/cespare/xxhash/v2 v2.3.0 // indirect github.com/chenzhuoyu/base64x v0.0.0-20230717121745-296ad89f973d // indirect github.com/chenzhuoyu/iasm v0.9.0 // indirect + github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575 // indirect github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc // indirect github.com/dgryski/go-rendezvous v0.0.0-20200823014737-9f7001d12a5f // indirect github.com/dustin/go-humanize v1.0.1 // indirect @@ -156,12 +163,13 @@ require ( github.com/ebitengine/purego v0.6.0-alpha.5 // indirect github.com/elastic/elastic-transport-go/v8 v8.1.0 // indirect github.com/fatih/color v1.16.0 // indirect - github.com/felixge/httpsnoop v1.0.3 // indirect + github.com/felixge/httpsnoop v1.0.4 // indirect github.com/gabriel-vasile/mimetype v1.4.2 // indirect github.com/gin-contrib/sse v0.1.0 // indirect github.com/go-jose/go-jose/v3 v3.0.3 // indirect - github.com/go-logr/logr v1.3.0 // indirect + github.com/go-logr/logr v1.4.1 // indirect github.com/go-logr/stdr v1.2.2 // indirect + github.com/go-ole/go-ole v1.2.6 // indirect github.com/go-pg/zerochecker v0.2.0 // indirect github.com/go-playground/locales v0.14.1 // indirect github.com/go-playground/universal-translator v0.18.1 // indirect @@ -173,11 +181,12 @@ require ( github.com/golang-sql/sqlexp v0.1.0 // indirect github.com/golang/groupcache v0.0.0-20210331224755-41bb18bfe9da // indirect github.com/golang/snappy v0.0.4 // indirect + github.com/google/gnostic v0.5.7-v3refs // indirect github.com/google/go-cmp v0.6.0 // indirect github.com/google/gofuzz v1.2.0 // indirect - github.com/google/s2a-go v0.1.5 // indirect - github.com/googleapis/enterprise-certificate-proxy v0.2.5 // indirect - github.com/googleapis/gax-go/v2 v2.11.0 // indirect + github.com/google/s2a-go v0.1.7 // indirect + github.com/googleapis/enterprise-certificate-proxy v0.3.2 // indirect + github.com/googleapis/gax-go/v2 v2.12.2 // indirect github.com/googleapis/gnostic v0.5.5 // indirect github.com/gorilla/websocket v1.5.0 // indirect github.com/hailocab/go-hostpool v0.0.0-20160125115350-e80d13ce29ed // indirect @@ -213,6 +222,7 @@ require ( github.com/klauspost/cpuid/v2 v2.2.5 // indirect github.com/labstack/gommon v0.4.0 // indirect github.com/leodido/go-urn v1.2.4 // indirect + github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c // indirect github.com/mailru/easyjson v0.7.7 // indirect github.com/mattn/go-colorable v0.1.13 // indirect github.com/mattn/go-isatty v0.0.20 // indirect @@ -227,11 +237,14 @@ require ( github.com/pierrec/lz4/v4 v4.1.18 // indirect github.com/pkg/errors v0.9.1 // indirect github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2 // indirect + github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c // indirect github.com/rcrowley/go-metrics v0.0.0-20201227073835-cf1acfcdf475 // indirect github.com/remyoudompheng/bigfft v0.0.0-20230129092748-24d4a6f8daec // indirect github.com/rivo/uniseg v0.4.4 // indirect github.com/ryanuber/go-glob v1.0.0 // indirect github.com/secure-systems-lab/go-securesystemslib v0.7.0 // indirect + github.com/shirou/gopsutil/v3 v3.24.4 // indirect + github.com/shoenig/go-m1cpu v0.1.6 // indirect github.com/spf13/pflag v1.0.5 // indirect github.com/stretchr/objx v0.5.2 // indirect github.com/tidwall/btree v1.6.0 // indirect @@ -241,6 +254,8 @@ require ( github.com/tidwall/pretty v1.2.1 // indirect github.com/tidwall/rtred v0.1.2 // indirect github.com/tidwall/tinyqueue v0.1.1 // indirect + github.com/tklauser/go-sysconf v0.3.12 // indirect + github.com/tklauser/numcpus v0.6.1 // indirect github.com/tmthrgd/go-hex v0.0.0-20190904060850-447a3041c3bc // indirect github.com/twitchyliquid64/golang-asm v0.15.1 // indirect github.com/ugorji/go/codec v1.2.11 // indirect @@ -255,26 +270,37 @@ require ( github.com/xdg-go/scram v1.1.2 // indirect github.com/xdg-go/stringprep v1.0.4 // indirect github.com/youmark/pkcs8 v0.0.0-20181117223130-1be2e3e5546d // indirect + github.com/yusufpapurcu/wmi v1.2.4 // indirect + go.einride.tech/aip v0.66.0 // indirect go.opencensus.io v0.24.0 // indirect - go.opentelemetry.io/otel/metric v1.20.0 // indirect + go.opentelemetry.io/collector/component v0.104.0 // indirect + go.opentelemetry.io/collector/config/configtelemetry v0.104.0 // indirect + go.opentelemetry.io/collector/pdata v1.11.0 // indirect + go.opentelemetry.io/collector/semconv v0.104.0 // indirect + go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.49.0 // indirect + go.opentelemetry.io/otel/metric v1.27.0 // indirect + go.opentelemetry.io/otel/sdk v1.27.0 // indirect + go.uber.org/multierr v1.11.0 // indirect + go.uber.org/zap v1.27.0 // indirect golang.org/x/arch v0.4.0 // indirect - golang.org/x/crypto v0.21.0 // indirect + golang.org/x/crypto v0.25.0 // indirect golang.org/x/exp v0.0.0-20230905200255-921286631fa9 // indirect - golang.org/x/sync v0.5.0 // indirect - golang.org/x/term v0.18.0 // indirect - golang.org/x/text v0.14.0 // indirect - golang.org/x/tools v0.16.1 // indirect - google.golang.org/appengine v1.6.7 // indirect - google.golang.org/genproto v0.0.0-20230530153820-e85fd2cbaebc // indirect - google.golang.org/genproto/googleapis/api v0.0.0-20230530153820-e85fd2cbaebc // indirect - google.golang.org/genproto/googleapis/rpc v0.0.0-20230530153820-e85fd2cbaebc // indirect + golang.org/x/sync v0.8.0 // indirect + golang.org/x/term v0.22.0 // indirect + golang.org/x/text v0.16.0 // indirect + golang.org/x/tools v0.23.0 // indirect + google.golang.org/appengine v1.6.8 // indirect + google.golang.org/genproto v0.0.0-20240213162025-012b6fc9bca9 // indirect + google.golang.org/genproto/googleapis/api v0.0.0-20240318140521-94a12d6c2237 // indirect + google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 // indirect gopkg.in/inf.v0 v0.9.1 // indirect + gopkg.in/ini.v1 v1.67.0 // indirect gopkg.in/yaml.v2 v2.4.0 // indirect gopkg.in/yaml.v3 v3.0.1 // indirect k8s.io/api v0.23.17 // indirect - k8s.io/klog/v2 v2.30.0 // indirect - k8s.io/kube-openapi v0.0.0-20211115234752-e816edb12b65 // indirect - k8s.io/utils v0.0.0-20211116205334-6203023598ed // indirect + k8s.io/klog/v2 v2.70.1 // indirect + k8s.io/kube-openapi v0.0.0-20220803162953-67bda5d908f1 // indirect + k8s.io/utils v0.0.0-20220728103510-ee6ede2d64ed // indirect lukechampine.com/uint128 v1.3.0 // indirect mellium.im/sasl v0.3.1 // indirect modernc.org/cc/v3 v3.41.0 // indirect @@ -285,7 +311,7 @@ require ( modernc.org/opt v0.1.3 // indirect modernc.org/strutil v1.2.0 // indirect modernc.org/token v1.1.0 // indirect - sigs.k8s.io/json v0.0.0-20211020170558-c049b76a60c6 // indirect + sigs.k8s.io/json v0.0.0-20220713155537-f223a00ba0e2 // indirect sigs.k8s.io/structured-merge-diff/v4 v4.2.3 // indirect sigs.k8s.io/yaml v1.2.0 // indirect ) diff --git a/go.sum b/go.sum index 32f99bb03f..b27f5af6d4 100644 --- a/go.sum +++ b/go.sum @@ -38,8 +38,8 @@ cloud.google.com/go v0.104.0/go.mod h1:OO6xxXdJyvuJPcEPBLN9BJPD+jep5G1+2U5B5gkRY cloud.google.com/go v0.105.0/go.mod h1:PrLgOJNe5nfE9UMxKxgXj4mD3voiP+YQ6gdt6KMFOKM= cloud.google.com/go v0.107.0/go.mod h1:wpc2eNrD7hXUTy8EKS10jkxpZBjASrORK7goS+3YX2I= cloud.google.com/go v0.110.0/go.mod h1:SJnCLqQ0FCFGSZMUNUf84MV3Aia54kn7pi8st7tMzaY= -cloud.google.com/go v0.110.7 h1:rJyC7nWRg2jWGZ4wSJ5nY65GTdYJkg0cd/uXb+ACI6o= -cloud.google.com/go v0.110.7/go.mod h1:+EYjdK8e5RME/VY/qLCAtuyALQ9q67dvuum8i+H5xsI= +cloud.google.com/go v0.112.1 h1:uJSeirPke5UNZHIb4SxfZklVSiWWVqW4oXlETwZziwM= +cloud.google.com/go v0.112.1/go.mod h1:+Vbu+Y1UU+I1rjmzeMOb/8RfkKJK2Gyxi1X6jJCZLo4= cloud.google.com/go/accessapproval v1.4.0/go.mod h1:zybIuC3KpDOvotz59lFe5qxRZx6C75OtwbisN56xYB4= cloud.google.com/go/accessapproval v1.5.0/go.mod h1:HFy3tuiGvMdcd/u+Cu5b9NkO1pEICJ46IR82PoUdplw= cloud.google.com/go/accessapproval v1.6.0/go.mod h1:R0EiYnwV5fsRFiKZkPHr6mwyk2wxUJ30nL4j2pcFY2E= @@ -170,8 +170,8 @@ cloud.google.com/go/compute v1.14.0/go.mod h1:YfLtxrj9sU4Yxv+sXzZkyPjEyPBZfXHUvj cloud.google.com/go/compute v1.15.1/go.mod h1:bjjoF/NtFUrkD/urWfdHaKuOPDR5nWIs63rR+SXhcpA= cloud.google.com/go/compute v1.18.0/go.mod h1:1X7yHxec2Ga+Ss6jPyjxRxpu2uu7PLgsOVXvgU0yacs= cloud.google.com/go/compute v1.19.0/go.mod h1:rikpw2y+UMidAe9tISo04EHNOIf42RLYF/q8Bs93scU= -cloud.google.com/go/compute v1.23.0 h1:tP41Zoavr8ptEqaW6j+LQOnyBBhO7OkOMAGrgLopTwY= -cloud.google.com/go/compute v1.23.0/go.mod h1:4tCnrn48xsqlwSAiLf1HXMQk8CONslYbdiEZc9FEIbM= +cloud.google.com/go/compute v1.25.1 h1:ZRpHJedLtTpKgr3RV1Fx23NuaAEN1Zfx9hw1u4aJdjU= +cloud.google.com/go/compute v1.25.1/go.mod h1:oopOIR53ly6viBYxaDhBfJwzUAxf1zE//uf3IB011ls= cloud.google.com/go/compute/metadata v0.1.0/go.mod h1:Z1VN+bulIf6bt4P/C37K4DyZYZEXYonfTBHHFPO/4UU= cloud.google.com/go/compute/metadata v0.2.0/go.mod h1:zFmK7XCadkQkj6TtorcaGlCW1hT1fIilQDwofLpJ20k= cloud.google.com/go/compute/metadata v0.2.1/go.mod h1:jgHgmJd2RKBGzXqF5LR2EZMGxBkeanZ9wwa75XHJgOM= @@ -308,8 +308,8 @@ cloud.google.com/go/iam v0.8.0/go.mod h1:lga0/y3iH6CX7sYqypWJ33hf7kkfXJag67naqGE cloud.google.com/go/iam v0.11.0/go.mod h1:9PiLDanza5D+oWFZiH1uG+RnRCfEGKoyl6yo4cgWZGY= cloud.google.com/go/iam v0.12.0/go.mod h1:knyHGviacl11zrtZUoDuYpDgLjvr28sLQaG0YB2GYAY= cloud.google.com/go/iam v0.13.0/go.mod h1:ljOg+rcNfzZ5d6f1nAUJ8ZIxOaZUVoS14bKCtaLZ/D0= -cloud.google.com/go/iam v1.1.2 h1:gacbrBdWcoVmGLozRuStX45YKvJtzIjJdAolzUs1sm4= -cloud.google.com/go/iam v1.1.2/go.mod h1:A5avdyVL2tCppe4unb0951eI9jreack+RJ0/d+KUZOU= +cloud.google.com/go/iam v1.1.6 h1:bEa06k05IO4f4uJonbB5iAgKTPpABy1ayxaIZV/GHVc= +cloud.google.com/go/iam v1.1.6/go.mod h1:O0zxdPeGBoFdWW3HWmBxJsk0pfvNM/p/qa82rWOGTwI= cloud.google.com/go/iap v1.4.0/go.mod h1:RGFwRJdihTINIe4wZ2iCP0zF/qu18ZwyKxrhMhygBEc= cloud.google.com/go/iap v1.5.0/go.mod h1:UH/CGgKd4KyohZL5Pt0jSKE4m3FR51qg6FKQ/z/Ix9A= cloud.google.com/go/iap v1.6.0/go.mod h1:NSuvI9C/j7UdjGjIde7t7HBz+QTwBcapPE07+sSRcLk= @@ -327,8 +327,8 @@ cloud.google.com/go/kms v1.6.0/go.mod h1:Jjy850yySiasBUDi6KFUwUv2n1+o7QZFyuUJg6O cloud.google.com/go/kms v1.8.0/go.mod h1:4xFEhYFqvW+4VMELtZyxomGSYtSQKzM178ylFW4jMAg= cloud.google.com/go/kms v1.9.0/go.mod h1:qb1tPTgfF9RQP8e1wq4cLFErVuTJv7UsSC915J8dh3w= cloud.google.com/go/kms v1.10.0/go.mod h1:ng3KTUtQQU9bPX3+QGLsflZIHlkbn8amFAMY63m8d24= -cloud.google.com/go/kms v1.11.0 h1:0LPJPKamw3xsVpkel1bDtK0vVJec3EyqdQOLitiD030= -cloud.google.com/go/kms v1.11.0/go.mod h1:hwdiYC0xjnWsKQQCQQmIQnS9asjYVSK6jtXm+zFqXLM= +cloud.google.com/go/kms v1.15.7 h1:7caV9K3yIxvlQPAcaFffhlT7d1qpxjB1wHBtjWa13SM= +cloud.google.com/go/kms v1.15.7/go.mod h1:ub54lbsa6tDkUwnu4W7Yt1aAIFLnspgh0kPGToDukeI= cloud.google.com/go/language v1.4.0/go.mod h1:F9dRpNFQmJbkaop6g0JhSBXCNlO90e1KWx5iDdxbWic= cloud.google.com/go/language v1.6.0/go.mod h1:6dJ8t3B+lUYfStgls25GusK04NLh3eDLQnWM3mdEbhI= cloud.google.com/go/language v1.7.0/go.mod h1:DJ6dYN/W+SQOjF8e1hLQXMF21AkH2w9wiPzPCJa2MIE= @@ -422,8 +422,8 @@ cloud.google.com/go/pubsub v1.26.0/go.mod h1:QgBH3U/jdJy/ftjPhTkyXNj543Tin1pRYcd cloud.google.com/go/pubsub v1.27.1/go.mod h1:hQN39ymbV9geqBnfQq6Xf63yNhUAhv9CZhzp5O6qsW0= cloud.google.com/go/pubsub v1.28.0/go.mod h1:vuXFpwaVoIPQMGXqRyUQigu/AX1S3IWugR9xznmcXX8= cloud.google.com/go/pubsub v1.30.0/go.mod h1:qWi1OPS0B+b5L+Sg6Gmc9zD1Y+HaM0MdUr7LsupY1P4= -cloud.google.com/go/pubsub v1.33.0 h1:6SPCPvWav64tj0sVX/+npCBKhUi/UjJehy9op/V3p2g= -cloud.google.com/go/pubsub v1.33.0/go.mod h1:f+w71I33OMyxf9VpMVcZbnG5KSUkCOUHYpFd5U1GdRc= +cloud.google.com/go/pubsub v1.36.1 h1:dfEPuGCHGbWUhaMCTHUFjfroILEkx55iUmKBZTP5f+Y= +cloud.google.com/go/pubsub v1.36.1/go.mod h1:iYjCa9EzWOoBiTdd4ps7QoMtMln5NwaZQpK1hbRfBDE= cloud.google.com/go/pubsublite v1.5.0/go.mod h1:xapqNQ1CuLfGi23Yda/9l4bBCKz/wC3KIJ5gKcxveZg= cloud.google.com/go/pubsublite v1.6.0/go.mod h1:1eFCS0U11xlOuMFV/0iBqw3zP12kddMeCbj/F3FSj9k= cloud.google.com/go/pubsublite v1.7.0/go.mod h1:8hVMwRXfDfvGm3fahVbtDbiLePT3gpoiJYJY+vxWxVM= @@ -627,19 +627,31 @@ github.com/BurntSushi/toml v0.3.1/go.mod h1:xHWCNGjB5oqiDr8zfno3MHue2Ht5sIBksp03 github.com/BurntSushi/xgb v0.0.0-20160522181843-27f122750802/go.mod h1:IVnqGOEym/WlBOVXweHU+Q+/VP0lqqI8lqeDx9IjBqo= github.com/DataDog/appsec-internal-go v1.7.0 h1:iKRNLih83dJeVya3IoUfK+6HLD/hQsIbyBlfvLmAeb0= github.com/DataDog/appsec-internal-go v1.7.0/go.mod h1:wW0cRfWBo4C044jHGwYiyh5moQV2x0AhnwqMuiX7O/g= -github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 h1:bUMSNsw1iofWiju9yc1f+kBd33E3hMJtq9GuU602Iy8= -github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0/go.mod h1:HzySONXnAgSmIQfL6gOv9hWprKJkx8CicuXuUbmgWfo= -github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 h1:5nE6N3JSs2IG3xzMthNFhXfOaXlrsdgqmJ73lndFf8c= -github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1/go.mod h1:Vc+snp0Bey4MrrJyiV2tVxxJb6BmLomPvN1RgAvjGaQ= +github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 h1:18/yZ0yKjCnTPkBW7K8LdRiRiVaYjKF0yE1QHfMA7yI= +github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1/go.mod h1:T+qq8YiHRRIuB9A1W1k9KE4Owr9anljl12Ztm7Nx8XU= +github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 h1:qq3MUh7MdkywBpjm0HRaYOfcunNemWI+wO4u2w1GWnA= +github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1/go.mod h1:5h7i2YkGEM4QOu4TUaYeSPZ1BeuXaseA276cCrSvCmM= +github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 h1:hVa76HpVox8Xt05qpLuqAngd9+1waSA5IVQqCFJ2RPQ= +github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= +github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 h1:iMJU0lqQvrpJ6LCLTWwbUlCWaazurhwwvWf8FKsaOs4= +github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1/go.mod h1:RdepkDr3A0tJ6G/B4MfMy1fzEYHovykN7pnXOK1vePg= +github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 h1:Bx5kkulMNaTgNH8/Piu0wpwOhd4BZR7Ht0SMv4zAKQg= +github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1/go.mod h1:S/D5aNZadFQk6IWKghTnuiKVyD+9OfSfsm116VY+xlU= +github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 h1:7IY8ST69RNo+x7Z2Y99BtsLPqFyTZWTh9LWWFYQBr3A= +github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1/go.mod h1:8ASCNWHQtcmUedxL+WjbCPSIcGIM8LeVzil7JCzx0js= github.com/DataDog/datadog-go v3.2.0+incompatible/go.mod h1:LButxg5PwREeZtORoXG3tL4fMGNddJ+vMq1mwgfaqoQ= -github.com/DataDog/datadog-go/v5 v5.3.0 h1:2q2qjFOb3RwAZNU+ez27ZVDwErJv5/VpbBPprz7Z+s8= -github.com/DataDog/datadog-go/v5 v5.3.0/go.mod h1:XRDJk1pTc00gm+ZDiBKsjh7oOOtJfYfglVCmFb8C2+Q= +github.com/DataDog/datadog-go/v5 v5.5.0 h1:G5KHeB8pWBNXT4Jtw0zAkhdxEAWSpWH00geHI6LDrKU= +github.com/DataDog/datadog-go/v5 v5.5.0/go.mod h1:K9kcYBlxkcPP8tvvjZZKs/m1edNAUFzBbdpTUKfCsuw= github.com/DataDog/go-libddwaf/v3 v3.3.0 h1:jS72fuQpFgJZEdEJDmHJCPAgNTEMZoz1EUvimPUOiJ4= github.com/DataDog/go-libddwaf/v3 v3.3.0/go.mod h1:Bz/0JkpGf689mzbUjKJeheJINqsyyhM8p9PDuHdK2Ec= -github.com/DataDog/go-tuf v1.0.2-0.5.2 h1:EeZr937eKAWPxJ26IykAdWA4A0jQXJgkhUjqEI/w7+I= -github.com/DataDog/go-tuf v1.0.2-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= +github.com/DataDog/go-sqllexer v0.0.13 h1:9mKfe+3s73GI/7dWBxi2Ds7+xZynJqMKK9cIUBrutak= +github.com/DataDog/go-sqllexer v0.0.13/go.mod h1:KwkYhpFEVIq+BfobkTC1vfqm4gTi65skV/DpDBXtexc= +github.com/DataDog/go-tuf v1.1.0-0.5.2 h1:4CagiIekonLSfL8GMHRHcHudo1fQnxELS9g4tiAupQ4= +github.com/DataDog/go-tuf v1.1.0-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= github.com/DataDog/gostackparse v0.7.0 h1:i7dLkXHvYzHV308hnkvVGDL3BR4FWl7IsXNPz/IGQh4= github.com/DataDog/gostackparse v0.7.0/go.mod h1:lTfqcJKqS9KnXQGnyQMCugq3u1FP6UZMfWR0aitKFMM= +github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0 h1:10TPqpTlIkmDPFWVIEZ4ZX3rWrCrx3rEoeoAooZr6LM= +github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0/go.mod h1:dvIWN9pA2zWNTw5rhDWZgzZnhcfpH++d+8d1SWW6xkY= github.com/DataDog/sketches-go v1.4.5 h1:ki7VfeNz7IcNafq7yI/j5U/YCkO3LJiMDtXz9OMQbyE= github.com/DataDog/sketches-go v1.4.5/go.mod h1:7Y8GN8Jf66DLyDhc94zuWA3uHEt/7ttt8jHOBWWrSOg= github.com/IBM/sarama v1.40.0 h1:QTVmX+gMKye52mT5x+Ve/Bod2D0Gy7ylE2Wslv+RHtc= @@ -792,6 +804,7 @@ github.com/benbjohnson/clock v1.0.3/go.mod h1:bGMdMPoPVvcYyt1gHDf4J2KE153Yf9BuiU github.com/beorn7/perks v0.0.0-20160804104726-4c0e84591b9a/go.mod h1:Dwedo/Wpr24TaqPxmxbtue+5NUziq4I4S80YR8gNf3Q= github.com/beorn7/perks v0.0.0-20180321164747-3a771d992973/go.mod h1:Dwedo/Wpr24TaqPxmxbtue+5NUziq4I4S80YR8gNf3Q= github.com/beorn7/perks v1.0.0/go.mod h1:KWe93zE9D1o94FZ5RNwFwVgaQK1VOXiVxmqh+CedLV8= +github.com/beorn7/perks v1.0.1 h1:VlbKKnNfV8bJzeqoa4cOKqO6bYr3WgKZxO8Z16+hsOM= github.com/beorn7/perks v1.0.1/go.mod h1:G2ZrVWU2WbWT9wwq4/hrbKbnv/1ERSJQ0ibhJ6rlkpw= github.com/bgentry/speakeasy v0.1.0/go.mod h1:+zsyZBPWlz7T6j88CTgSN5bM796AkVf0kBD4zp0CCIs= github.com/bitly/go-hostpool v0.0.0-20171023180738-a3a6125de932 h1:mXoPYz/Ul5HYEDvkta6I8/rnYM5gSdSV2tJ6XbZuEtY= @@ -835,8 +848,9 @@ github.com/certifi/gocertifi v0.0.0-20200922220541-2c3bb06c6054/go.mod h1:sGbDF6 github.com/cespare/xxhash v1.1.0/go.mod h1:XrSqR1VqqWfGrhpAt58auRo0WTKS1nRRg3ghfAqPWnc= github.com/cespare/xxhash/v2 v2.1.1/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= github.com/cespare/xxhash/v2 v2.1.2/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= -github.com/cespare/xxhash/v2 v2.2.0 h1:DC2CZ1Ep5Y4k3ZQ899DldepgrayRUGE6BBZ/cd9Cj44= github.com/cespare/xxhash/v2 v2.2.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= +github.com/cespare/xxhash/v2 v2.3.0 h1:UL815xU9SqsFlibzuggzjXhog7bL6oX9BbNZnL2UFvs= +github.com/cespare/xxhash/v2 v2.3.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= github.com/checkpoint-restore/go-criu/v4 v4.1.0/go.mod h1:xUQBLp4RLc5zJtWY++yjOoMoB5lihDt7fai+75m+rGw= github.com/checkpoint-restore/go-criu/v5 v5.0.0/go.mod h1:cfwC0EG7HMUenopBsUf9d89JlCLQIfgVcNsNN0t6T2M= github.com/checkpoint-restore/go-criu/v5 v5.3.0/go.mod h1:E/eQpaFtUKGOOSEBZgmKAcn+zUUwWxqcaKZlF54wK8E= @@ -849,6 +863,8 @@ github.com/chenzhuoyu/iasm v0.9.0/go.mod h1:Xjy2NpN3h7aUqeqM+woSuuvxmIe6+DDsiNLI github.com/chzyer/logex v1.1.10/go.mod h1:+Ywpsq7O8HXn0nuIou7OrIPyXbp3wmkHB+jjWRnGsAI= github.com/chzyer/readline v0.0.0-20180603132655-2972be24d48e/go.mod h1:nSuG5e5PlCu98SY8svDHJxuZscDgtXS6KTTbou5AhLI= github.com/chzyer/test v0.0.0-20180213035817-a1ea475d72b1/go.mod h1:Q3SI9o4m/ZMnBNeIyt5eFwwo7qiLfzFZmjNmxjkiQlU= +github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575 h1:kHaBemcxl8o/pQ5VM1c8PVE1PubbNx3mjUr09OqWGCs= +github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575/go.mod h1:9d6lWj8KzO/fd/NrVaLscBKmPigpZpn5YawRPw+e3Yo= github.com/cilium/ebpf v0.0.0-20200110133405-4032b1d8aae3/go.mod h1:MA5e5Lr8slmEg9bt0VpxxWqJlO4iwu3FBdHUzV7wQVg= github.com/cilium/ebpf v0.0.0-20200702112145-1c8d4c9ef775/go.mod h1:7cR51M8ViRLIdUjrmSXlK9pkrsDlLHbO8jiB8X8JnOc= github.com/cilium/ebpf v0.2.0/go.mod h1:To2CFviqOWL/M0gIMsvSMlqe7em/l1ALkX1PyjrX2Qs= @@ -1022,8 +1038,9 @@ github.com/denisenkom/go-mssqldb v0.11.0/go.mod h1:xbL0rPBG9cCiLr28tMa8zpbdarY27 github.com/denverdino/aliyungo v0.0.0-20190125010748-a747050bb1ba/go.mod h1:dV8lFg6daOBZbT6/BDGIz6Y3WFGn8juu6G+CQ6LHtl0= github.com/dgrijalva/jwt-go v0.0.0-20170104182250-a601269ab70c/go.mod h1:E3ru+11k8xSBh+hMPgOLZmtrrCbhqsmaPHjLKYnJCaQ= github.com/dgrijalva/jwt-go v3.2.0+incompatible/go.mod h1:E3ru+11k8xSBh+hMPgOLZmtrrCbhqsmaPHjLKYnJCaQ= -github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2 h1:tdlZCpZ/P9DhczCTSixgIKmwPv6+wP5DGjqLYw5SUiA= github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2/go.mod h1:SqUrOPUnsFjfmXRMNPybcSiG0BgUW2AuFH8PAnS2iTw= +github.com/dgryski/go-farm v0.0.0-20200201041132-a6ae2369ad13 h1:fAjc9m62+UWV/WAFKLNi6ZS0675eEUC9y3AlwSbQu1Y= +github.com/dgryski/go-farm v0.0.0-20200201041132-a6ae2369ad13/go.mod h1:SqUrOPUnsFjfmXRMNPybcSiG0BgUW2AuFH8PAnS2iTw= github.com/dgryski/go-rendezvous v0.0.0-20200823014737-9f7001d12a5f h1:lO4WD4F/rVNCu3HqELle0jiPLLBs70cWOduZpkS1E78= github.com/dgryski/go-rendezvous v0.0.0-20200823014737-9f7001d12a5f/go.mod h1:cuUVRXasLTGF7a8hSLbxyZXjz+1KgoB3wDUb6vlszIc= github.com/dgryski/go-sip13 v0.0.0-20181026042036-e10d5fee7954/go.mod h1:vAd38F8PWV+bWy6jNmig1y/TA+kYO4g3RSRF0IAv0no= @@ -1110,8 +1127,8 @@ github.com/fatih/color v1.13.0/go.mod h1:kLAiJbzzSOZDVNGyDpeOxJ47H46qBXwg5ILebYF github.com/fatih/color v1.16.0 h1:zmkK9Ngbjj+K0yRhTVONQh1p/HknKYSlNT+vZCzyokM= github.com/fatih/color v1.16.0/go.mod h1:fL2Sau1YI5c0pdGEVCbKQbLXB6edEj1ZgiY4NijnWvE= github.com/felixge/httpsnoop v1.0.1/go.mod h1:m8KPJKqk1gH5J9DgRY2ASl2lWCfGKXixSwevea8zH2U= -github.com/felixge/httpsnoop v1.0.3 h1:s/nj+GCswXYzN5v2DpNMuMQYe+0DDwt5WVCU6CWBdXk= -github.com/felixge/httpsnoop v1.0.3/go.mod h1:m8KPJKqk1gH5J9DgRY2ASl2lWCfGKXixSwevea8zH2U= +github.com/felixge/httpsnoop v1.0.4 h1:NFTV2Zj1bL4mc9sqWACXbQFVBBg2W3GPvqp8/ESS2Wg= +github.com/felixge/httpsnoop v1.0.4/go.mod h1:m8KPJKqk1gH5J9DgRY2ASl2lWCfGKXixSwevea8zH2U= github.com/fogleman/gg v1.2.1-0.20190220221249-0403632d5b90/go.mod h1:R/bRT+9gY/C5z7JzPU0zXsXHKM4/ayA+zqcVNZzPa1k= github.com/fogleman/gg v1.3.0/go.mod h1:R/bRT+9gY/C5z7JzPU0zXsXHKM4/ayA+zqcVNZzPa1k= github.com/form3tech-oss/jwt-go v3.2.2+incompatible/go.mod h1:pbq4aXjuKjdthFRnoDwaVPLA+WlJuPGy+QneDUgJi2k= @@ -1133,7 +1150,6 @@ github.com/gabriel-vasile/mimetype v1.4.2/go.mod h1:zApsH/mKG4w07erKIaJPFiX0Tsq9 github.com/garyburd/redigo v0.0.0-20150301180006-535138d7bcd7/go.mod h1:NR3MbYisc3/PwhQ00EMzDiPmrwpPxAn5GI05/YaO1SY= github.com/garyburd/redigo v1.6.4 h1:LFu2R3+ZOPgSMWMOL+saa/zXRjw0ID2G8FepO53BGlg= github.com/garyburd/redigo v1.6.4/go.mod h1:rTb6epsqigu3kYKBnaF028A7Tf/Aw5s0cqA47doKKqw= -github.com/getkin/kin-openapi v0.76.0/go.mod h1:660oXbgy5JFMKreazJaQTw7o+X00qeSyhcnluiMv+Xg= github.com/getsentry/raven-go v0.2.0/go.mod h1:KungGk8q33+aIAZUIVWZDr2OfAEBsO49PX4NzFV5kcQ= github.com/ghodss/yaml v0.0.0-20150909031657-73d445a93680/go.mod h1:4dBDuWmgqj2HViK6kFavaiC9ZROes6MMH2rRYeMEF04= github.com/ghodss/yaml v1.0.0/go.mod h1:4dBDuWmgqj2HViK6kFavaiC9ZROes6MMH2rRYeMEF04= @@ -1175,11 +1191,13 @@ github.com/go-logr/logr v1.2.0/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbV github.com/go-logr/logr v1.2.1/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= github.com/go-logr/logr v1.2.2/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= github.com/go-logr/logr v1.2.3/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= -github.com/go-logr/logr v1.3.0 h1:2y3SDp0ZXuc6/cjLSZ+Q3ir+QB9T/iG5yYRXqsagWSY= -github.com/go-logr/logr v1.3.0/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= +github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= +github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= github.com/go-logr/stdr v1.2.0/go.mod h1:YkVgnZu1ZjjL7xTxrfm/LLZBfkhTqSR1ydtm6jTKKwI= github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= +github.com/go-ole/go-ole v1.2.6 h1:/Fpf6oFPoeFik9ty7siob0G6Ke8QvQEuVcuChpwXzpY= +github.com/go-ole/go-ole v1.2.6/go.mod h1:pprOEPIfldk/42T2oK7lQ4v4JSDwmV0As9GaiUsvbm0= github.com/go-openapi/jsonpointer v0.0.0-20160704185906-46af16f9f7b1/go.mod h1:+35s3my2LFTysnkMfxsJBAMHj/DoqoB9knIWoYG/Vk0= github.com/go-openapi/jsonpointer v0.19.2/go.mod h1:3akKfEdA7DF1sugOqz1dVQHBcuDBPKZGEoHC/NkiQRg= github.com/go-openapi/jsonpointer v0.19.3/go.mod h1:Pl9vOtqEWErmShwVjC8pYs9cog34VGT37dQOVbmoatg= @@ -1290,8 +1308,9 @@ github.com/golang/protobuf v1.4.3/go.mod h1:oDoupMAO8OvCJWAcko0GGGIgR6R6ocIYbsSw github.com/golang/protobuf v1.5.0/go.mod h1:FsONVRAS9T7sI+LIUmWTfcYkHO4aIWwzhcaSAoJOfIk= github.com/golang/protobuf v1.5.1/go.mod h1:DopwsBzvsk0Fs44TXzsVbJyPhcCPeIwnvohx4u74HPM= github.com/golang/protobuf v1.5.2/go.mod h1:XVQd3VNwM+JqD3oG2Ue2ip4fOMUkwXdXDdiuN0vRsmY= -github.com/golang/protobuf v1.5.3 h1:KhyjKVUg7Usr/dYsdSqoFveMYd5ko72D+zANwlG1mmg= github.com/golang/protobuf v1.5.3/go.mod h1:XVQd3VNwM+JqD3oG2Ue2ip4fOMUkwXdXDdiuN0vRsmY= +github.com/golang/protobuf v1.5.4 h1:i7eJL8qZTpSEXOPTxNKhASYpMn+8e5Q6AdndVa1dWek= +github.com/golang/protobuf v1.5.4/go.mod h1:lnTiLA8Wa4RWRcIUkrtSVa5nRhsEGBg48fD6rSs7xps= github.com/golang/snappy v0.0.1/go.mod h1:/XxbfmMg8lxefKM7IXC3fBNl/7bRcc72aCRzEWrmP2Q= github.com/golang/snappy v0.0.3/go.mod h1:/XxbfmMg8lxefKM7IXC3fBNl/7bRcc72aCRzEWrmP2Q= github.com/golang/snappy v0.0.4 h1:yAGX7huGHXlcLOEtBnF4w7FQwA26wojNCwOYAEhLjQM= @@ -1303,6 +1322,8 @@ github.com/google/btree v1.0.0/go.mod h1:lNA+9X1NB3Zf8V7Ke586lFgjr2dZNuvo3lPJSGZ github.com/google/btree v1.0.1 h1:gK4Kx5IaGY9CD5sPJ36FHiBJ6ZXl0kilRiiCj+jdYp4= github.com/google/btree v1.0.1/go.mod h1:xXMiIv4Fb/0kKde4SpL7qlzvu5cMJDRkFDxJfI9uaxA= github.com/google/flatbuffers v2.0.8+incompatible/go.mod h1:1AeVuKshWv4vARoZatz6mlQ0JxURH0Kv5+zNeJKJCa8= +github.com/google/gnostic v0.5.7-v3refs h1:FhTMOKj2VhjpouxvWJAV1TL304uMlb9zcDqkl6cEI54= +github.com/google/gnostic v0.5.7-v3refs/go.mod h1:73MKFl6jIHelAJNaBGFzt3SPtZULs9dYrGFt8OiIsHQ= github.com/google/go-cmp v0.2.0/go.mod h1:oXzfMopK8JAjlY9xF4vHSVASa0yLyX7SntLO5aqRK0M= github.com/google/go-cmp v0.2.1-0.20190312032427-6f77996f0c42/go.mod h1:8QqcDgzrUqlUb/G2PQTWiueGozuR1884gddMywk6iLU= github.com/google/go-cmp v0.3.0/go.mod h1:8QqcDgzrUqlUb/G2PQTWiueGozuR1884gddMywk6iLU= @@ -1351,23 +1372,23 @@ github.com/google/pprof v0.0.0-20211008130755-947d60d73cc0/go.mod h1:KgnwoLYCZ8I github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b h1:h9U78+dx9a4BKdQkBBos92HalKpaGKHrp+3Uo6yTodo= github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b/go.mod h1:czg5+yv1E0ZGTi6S6vVK1mke0fV+FaUhNGcd6VRS9Ik= github.com/google/renameio v0.1.0/go.mod h1:KWCgfxg9yswjAJkECMjeO8J8rahYeXnNhOm40UhjYkI= -github.com/google/s2a-go v0.1.5 h1:8IYp3w9nysqv3JH+NJgXJzGbDHzLOTj43BmSkp+O7qg= -github.com/google/s2a-go v0.1.5/go.mod h1:Ej+mSEMGRnqRzjc7VtF+jdBwYG5fuJfiZ8ELkjEwM0A= +github.com/google/s2a-go v0.1.7 h1:60BLSyTrOV4/haCDW4zb1guZItoSq8foHCXrAnjBo/o= +github.com/google/s2a-go v0.1.7/go.mod h1:50CgR4k1jNlWBu4UfS4AcfhVe1r6pdZPygJ3R8F0Qdw= github.com/google/shlex v0.0.0-20191202100458-e7afc7fbc510/go.mod h1:pupxD2MaaD3pAXIBCelhxNneeOaAeabZDe5s4K6zSpQ= github.com/google/uuid v1.0.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/google/uuid v1.1.1/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/google/uuid v1.1.2/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/google/uuid v1.2.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/google/uuid v1.3.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= -github.com/google/uuid v1.5.0 h1:1p67kYwdtXjb0gL0BPiP1Av9wiZPo5A8z2cWkTZ+eyU= -github.com/google/uuid v1.5.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= +github.com/google/uuid v1.6.0 h1:NIvaJDMOsjHA8n1jAhLSgzrAzy1Hgr+hNrb57e+94F0= +github.com/google/uuid v1.6.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/googleapis/enterprise-certificate-proxy v0.0.0-20220520183353-fd19c99a87aa/go.mod h1:17drOmN3MwGY7t0e+Ei9b45FFGA3fBs3x36SsCg1hq8= github.com/googleapis/enterprise-certificate-proxy v0.1.0/go.mod h1:17drOmN3MwGY7t0e+Ei9b45FFGA3fBs3x36SsCg1hq8= github.com/googleapis/enterprise-certificate-proxy v0.2.0/go.mod h1:8C0jb7/mgJe/9KK8Lm7X9ctZC2t60YyIpYEI16jx0Qg= github.com/googleapis/enterprise-certificate-proxy v0.2.1/go.mod h1:AwSRAtLfXpU5Nm3pW+v7rGDHp09LsPtGY9MduiEsR9k= github.com/googleapis/enterprise-certificate-proxy v0.2.3/go.mod h1:AwSRAtLfXpU5Nm3pW+v7rGDHp09LsPtGY9MduiEsR9k= -github.com/googleapis/enterprise-certificate-proxy v0.2.5 h1:UR4rDjcgpgEnqpIEvkiqTYKBCKLNmlge2eVjoZfySzM= -github.com/googleapis/enterprise-certificate-proxy v0.2.5/go.mod h1:RxW0N9901Cko1VOCW3SXCpWP+mlIEkk2tP7jnHy9a3w= +github.com/googleapis/enterprise-certificate-proxy v0.3.2 h1:Vie5ybvEvT75RniqhfFxPRy3Bf7vr3h0cechB90XaQs= +github.com/googleapis/enterprise-certificate-proxy v0.3.2/go.mod h1:VLSiSSBs/ksPL8kq3OBOQ6WRI2QnaFynd1DCjZ62+V0= github.com/googleapis/gax-go/v2 v2.0.4/go.mod h1:0Wqv26UfaUD9n4G6kQubkQ+KchISgw+vpHVxEJEs9eg= github.com/googleapis/gax-go/v2 v2.0.5/go.mod h1:DWXyrwAJ9X0FpwwEdw+IPEYBICEFu5mhpdKc/us6bOk= github.com/googleapis/gax-go/v2 v2.1.0/go.mod h1:Q3nei7sK6ybPYH7twZdmQpAd1MKb7pfu6SK+H1/DsU0= @@ -1379,8 +1400,8 @@ github.com/googleapis/gax-go/v2 v2.5.1/go.mod h1:h6B0KMMFNtI2ddbGJn3T3ZbwkeT6yqE github.com/googleapis/gax-go/v2 v2.6.0/go.mod h1:1mjbznJAPHFpesgE5ucqfYEscaz5kMdcIDwU/6+DDoY= github.com/googleapis/gax-go/v2 v2.7.0/go.mod h1:TEop28CZZQ2y+c0VxMUmu1lV+fQx57QpBWsYpwqHJx8= github.com/googleapis/gax-go/v2 v2.7.1/go.mod h1:4orTrqY6hXxxaUL4LHIPl6lGo8vAE38/qKbhSAKP6QI= -github.com/googleapis/gax-go/v2 v2.11.0 h1:9V9PWXEsWnPpQhu/PeQIkS4eGzMlTLGgt80cUUI8Ki4= -github.com/googleapis/gax-go/v2 v2.11.0/go.mod h1:DxmR61SGKkGLa2xigwuZIQpkCI2S5iydzRfb3peWZJI= +github.com/googleapis/gax-go/v2 v2.12.2 h1:mhN09QQW1jEWeMF74zGR81R30z4VJzjZsfkUhuHF+DA= +github.com/googleapis/gax-go/v2 v2.12.2/go.mod h1:61M8vcyyXR2kqKFxKrfA22jaA8JGF7Dc8App1U3H6jc= github.com/googleapis/gnostic v0.4.1/go.mod h1:LRhVm6pbyptWbWbuZ38d1eyptfvIytN3ir6b65WBswg= github.com/googleapis/gnostic v0.5.1/go.mod h1:6U4PtQXGIEt/Z3h5MAT7FNofLnw9vXk2cUuW7uA/OeU= github.com/googleapis/gnostic v0.5.5 h1:9fHAtK0uDfpveeqqo1hkEZJcFvYXAiCN3UutL8F9xHw= @@ -1466,8 +1487,8 @@ github.com/hashicorp/go-uuid v1.0.1/go.mod h1:6SBZvOh/SIDV7/2o3Jml5SYk/TvGqwFJ/b github.com/hashicorp/go-uuid v1.0.2/go.mod h1:6SBZvOh/SIDV7/2o3Jml5SYk/TvGqwFJ/bN7x4byOro= github.com/hashicorp/go-uuid v1.0.3 h1:2gKiV6YVmrJ1i2CKKa9obLvRieoRGviZFL26PcT/Co8= github.com/hashicorp/go-uuid v1.0.3/go.mod h1:6SBZvOh/SIDV7/2o3Jml5SYk/TvGqwFJ/bN7x4byOro= -github.com/hashicorp/go-version v1.6.0 h1:feTTfFNnjP967rlCxM/I9g701jU+RN74YKx2mOkIeek= -github.com/hashicorp/go-version v1.6.0/go.mod h1:fltr4n8CU8Ke44wwGCBoEymUuxUHl09ZGVZPK5anwXA= +github.com/hashicorp/go-version v1.7.0 h1:5tqGy27NaOTB8yJKUZELlFAS/LTKJkrmONwQKeRZfjY= +github.com/hashicorp/go-version v1.7.0/go.mod h1:fltr4n8CU8Ke44wwGCBoEymUuxUHl09ZGVZPK5anwXA= github.com/hashicorp/go.net v0.0.1/go.mod h1:hjKkEWcCURg++eb33jQU7oqQcI9XDCnUzHA0oac0k90= github.com/hashicorp/golang-lru v0.5.0/go.mod h1:/m3WP610KZHVQ1SGc6re/UDhFvYD7pJ4Ao+sR/qLZy8= github.com/hashicorp/golang-lru v0.5.1/go.mod h1:/m3WP610KZHVQ1SGc6re/UDhFvYD7pJ4Ao+sR/qLZy8= @@ -1606,8 +1627,9 @@ github.com/kr/logfmt v0.0.0-20140226030751-b84e30acd515/go.mod h1:+0opPa2QZZtGFB github.com/kr/pretty v0.1.0/go.mod h1:dAy3ld7l9f0ibDNOQOHHMYYIIbhfbHSm3C4ZsoJORNo= github.com/kr/pretty v0.2.0/go.mod h1:ipq/a2n7PKx3OHsz4KJII5eveXtPO4qwEXGdVfWzfnI= github.com/kr/pretty v0.2.1/go.mod h1:ipq/a2n7PKx3OHsz4KJII5eveXtPO4qwEXGdVfWzfnI= -github.com/kr/pretty v0.3.0 h1:WgNl7dwNpEZ6jJ9k1snq4pZsg7DOEN8hP9Xw0Tsjwk0= github.com/kr/pretty v0.3.0/go.mod h1:640gp4NfQd8pI5XOwp5fnNeVWj67G7CFk/SaSQn7NBk= +github.com/kr/pretty v0.3.1 h1:flRD4NNwYAUpkphVc1HcthR4KEIFJ65n8Mw5qdRn3LE= +github.com/kr/pretty v0.3.1/go.mod h1:hoEshYVHaxMs3cyo3Yncou5ZscifuDolrwPKZanG3xk= github.com/kr/pty v1.1.1/go.mod h1:pFQYn66WHrOpPYNljwOMqo10TkYh1fy3cYio2l3bCsQ= github.com/kr/pty v1.1.5/go.mod h1:9r2w37qlBe7rQ6e1fg1S/9xpWHSnaqNdHD3WcMdbPDA= github.com/kr/text v0.1.0/go.mod h1:4Jbv+DJW3UT/LiOwJeYQe1efqtUx/iVham/4vfdArNI= @@ -1631,6 +1653,9 @@ github.com/linkedin/goavro/v2 v2.10.0/go.mod h1:UgQUb2N/pmueQYH9bfqFioWxzYCZXSfF github.com/linkedin/goavro/v2 v2.10.1/go.mod h1:UgQUb2N/pmueQYH9bfqFioWxzYCZXSfF8Jw03O5sjqA= github.com/linkedin/goavro/v2 v2.11.1/go.mod h1:UgQUb2N/pmueQYH9bfqFioWxzYCZXSfF8Jw03O5sjqA= github.com/linuxkit/virtsock v0.0.0-20201010232012-f8cee7dfc7a3/go.mod h1:3r6x7q95whyfWQpmGZTu3gk3v2YkMi05HEzl7Tf7YEo= +github.com/lufia/plan9stats v0.0.0-20211012122336-39d0f177ccd0/go.mod h1:zJYVVT2jmtg6P3p1VtQj7WsuWi/y4VnjVBn7F8KPB3I= +github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c h1:VtwQ41oftZwlMnOEbMWQtSEUgU64U4s+GHk7hZK+jtY= +github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c/go.mod h1:JKx41uQRwqlTZabZc+kILPrO/3jlKnQ2Z8b7YiVw5cE= github.com/lyft/protoc-gen-star v0.6.0/go.mod h1:TGAoBVkt8w7MPG72TrKIu85MIdXwDuzJYeZuUPFPNwA= github.com/lyft/protoc-gen-star v0.6.1/go.mod h1:TGAoBVkt8w7MPG72TrKIu85MIdXwDuzJYeZuUPFPNwA= github.com/magiconair/properties v1.8.0/go.mod h1:PppfXfuXeibc/6YijjN8zIbojt8czPbwD3XqdrwzmxQ= @@ -1702,8 +1727,8 @@ github.com/mitchellh/iochan v1.0.0/go.mod h1:JwYml1nuB7xOzsp52dPpHFffvOCDupsG0Qu github.com/mitchellh/mapstructure v0.0.0-20160808181253-ca63d7c062ee/go.mod h1:FVVH3fgwuzCH5S8UJGiWEs2h04kUh9fWfEaFds41c1Y= github.com/mitchellh/mapstructure v1.1.2/go.mod h1:FVVH3fgwuzCH5S8UJGiWEs2h04kUh9fWfEaFds41c1Y= github.com/mitchellh/mapstructure v1.4.1/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= -github.com/mitchellh/mapstructure v1.5.0 h1:jeMsZIYE/09sWLaz43PL7Gy6RuMjD2eJVyuac5Z2hdY= -github.com/mitchellh/mapstructure v1.5.0/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= +github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c h1:cqn374mizHuIWj+OSJCajGr/phAmuMug9qIX3l9CflE= +github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= github.com/mitchellh/osext v0.0.0-20151018003038-5e2d6d41470f/go.mod h1:OkQIRizQZAeMln+1tSwduZz7+Af5oFlKirV/MSYes2A= github.com/moby/locker v1.0.1/go.mod h1:S7SDdo5zpBK84bzzVlKr2V0hz+7x9hWbYC/kq7oQppc= github.com/moby/patternmatcher v0.5.0 h1:YCZgJOeULcxLw1Q+sVR636pmS7sPEn1Qo2iAN6M7DBo= @@ -1769,6 +1794,8 @@ github.com/onsi/ginkgo v1.16.5 h1:8xi0RTUf59SOSfEtZMvwTvXYMzG4gV23XVHOZiXNtnE= github.com/onsi/ginkgo v1.16.5/go.mod h1:+E8gABHa3K6zRBolWtd+ROzc/U5bkGt0FwiG042wbpU= github.com/onsi/ginkgo/v2 v2.0.0/go.mod h1:vw5CSIxN1JObi/U8gcbwft7ZxR2dgaR70JSE3/PpL4c= github.com/onsi/ginkgo/v2 v2.1.3/go.mod h1:vw5CSIxN1JObi/U8gcbwft7ZxR2dgaR70JSE3/PpL4c= +github.com/onsi/ginkgo/v2 v2.1.6 h1:Fx2POJZfKRQcM1pH49qSZiYeu319wji004qX+GDovrU= +github.com/onsi/ginkgo/v2 v2.1.6/go.mod h1:MEH45j8TBi6u9BMogfbp0stKC5cdGjumZj5Y7AG4VIk= github.com/onsi/gomega v0.0.0-20151007035656-2152b45fa28a/go.mod h1:C1qb7wdrVGGVU+Z6iS04AVkA3Q65CEZX59MT0QO5uiA= github.com/onsi/gomega v0.0.0-20170829124025-dcabb60a477c/go.mod h1:C1qb7wdrVGGVU+Z6iS04AVkA3Q65CEZX59MT0QO5uiA= github.com/onsi/gomega v1.5.0/go.mod h1:ex+gbHU/CVuBBDIJjb2X0qEXbFg53c61hWP/1CpauHY= @@ -1780,8 +1807,9 @@ github.com/onsi/gomega v1.10.3/go.mod h1:V9xEwhxec5O8UDM77eCW8vLymOMltsqPVYWrpDs github.com/onsi/gomega v1.15.0/go.mod h1:cIuvLEne0aoVhAgh/O6ac0Op8WWw9H6eYCriF+tEHG0= github.com/onsi/gomega v1.17.0/go.mod h1:HnhC7FXeEQY45zxNK3PPoIUhzk/80Xly9PcubAlGdZY= github.com/onsi/gomega v1.18.1/go.mod h1:0q+aL8jAiMXy9hbwj2mr5GziHiwhAIQpFmmtT5hitRs= -github.com/onsi/gomega v1.19.0 h1:4ieX6qQjPP/BfC3mpsAtIGGlxTWPeA3Inl/7DtXw1tw= github.com/onsi/gomega v1.19.0/go.mod h1:LY+I3pBVzYsTBU1AnDwOSxaYi9WoWiqgwooUqq9yPro= +github.com/onsi/gomega v1.20.1 h1:PA/3qinGoukvymdIDV8pii6tiZgC8kbmJO6Z5+b002Q= +github.com/onsi/gomega v1.20.1/go.mod h1:DtrZpjmvpn2mPm4YWQa0/ALMDj9v4YxLgojwPeREyVo= github.com/opencontainers/go-digest v0.0.0-20170106003457-a6d0ee40d420/go.mod h1:cMLVZDEM3+U2I4VmLI6N8jQYUd2OVphdqWwCJHrFt2s= github.com/opencontainers/go-digest v0.0.0-20180430190053-c9281466c8b2/go.mod h1:cMLVZDEM3+U2I4VmLI6N8jQYUd2OVphdqWwCJHrFt2s= github.com/opencontainers/go-digest v1.0.0-rc1/go.mod h1:cMLVZDEM3+U2I4VmLI6N8jQYUd2OVphdqWwCJHrFt2s= @@ -1855,6 +1883,9 @@ github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2 h1:Jamvg5psRI github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2/go.mod h1:iKH77koFhYxTK1pcRnkKkqfTogsbg7gZNVY4sRDYZ/4= github.com/posener/complete v1.1.1/go.mod h1:em0nMJCgc9GFtwrmVmEMR/ZL6WyhyjMBndrE9hABlRI= github.com/posener/complete v1.2.3/go.mod h1:WZIdtGGp+qx0sLrYKtIRAruyNpv6hFCicSgv7Sy7s/s= +github.com/power-devops/perfstat v0.0.0-20210106213030-5aafc221ea8c/go.mod h1:OmDBASR4679mdNQnz2pUhc2G8CO2JrUAVFDRBDP/hJE= +github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c h1:NRoLoZvkBTKvR5gQLgA3e0hqjkY9u1wm+iOL45VN/qI= +github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c/go.mod h1:OmDBASR4679mdNQnz2pUhc2G8CO2JrUAVFDRBDP/hJE= github.com/pquerna/cachecontrol v0.0.0-20171018203845-0dec1b30a021/go.mod h1:prYjPmNq4d1NPVmpShWobRqXY3q7Vp+80DqgxxUrUIA= github.com/prometheus/client_golang v0.0.0-20180209125602-c332b6f63c06/go.mod h1:7SWBe2y4D6OKWSNQJUaRYU/AaXPKyh/dDVn+NZz0KFw= github.com/prometheus/client_golang v0.9.1/go.mod h1:7SWBe2y4D6OKWSNQJUaRYU/AaXPKyh/dDVn+NZz0KFw= @@ -1865,11 +1896,15 @@ github.com/prometheus/client_golang v1.4.0/go.mod h1:e9GMxYsXl05ICDXkRhurwBS4Q3O github.com/prometheus/client_golang v1.7.1/go.mod h1:PY5Wy2awLA44sXw4AOSfFBetzPP4j5+D6mVACh+pe2M= github.com/prometheus/client_golang v1.11.0/go.mod h1:Z6t4BnS23TR94PD6BsDNk8yVqroYurpAkEiz0P2BEV0= github.com/prometheus/client_golang v1.11.1/go.mod h1:Z6t4BnS23TR94PD6BsDNk8yVqroYurpAkEiz0P2BEV0= +github.com/prometheus/client_golang v1.19.1 h1:wZWJDwK+NameRJuPGDhlnFgx8e8HN3XHQeLaYJFJBOE= +github.com/prometheus/client_golang v1.19.1/go.mod h1:mP78NwGzrVks5S2H6ab8+ZZGJLZUq1hoULYBAYBw1Ho= github.com/prometheus/client_model v0.0.0-20171117100541-99fa1f4be8e5/go.mod h1:MbSGuTsp3dbXC40dX6PRTWyKYBIrTGTE9sqQNg2J8bo= github.com/prometheus/client_model v0.0.0-20180712105110-5c3871d89910/go.mod h1:MbSGuTsp3dbXC40dX6PRTWyKYBIrTGTE9sqQNg2J8bo= github.com/prometheus/client_model v0.0.0-20190129233127-fd36f4220a90/go.mod h1:xMI15A0UPsDsEKsMN9yxemIoYk6Tm2C1GtYGdfGttqA= github.com/prometheus/client_model v0.0.0-20190812154241-14fe0d1b01d4/go.mod h1:xMI15A0UPsDsEKsMN9yxemIoYk6Tm2C1GtYGdfGttqA= github.com/prometheus/client_model v0.2.0/go.mod h1:xMI15A0UPsDsEKsMN9yxemIoYk6Tm2C1GtYGdfGttqA= +github.com/prometheus/client_model v0.6.1 h1:ZKSh/rekM+n3CeS952MLRAdFwIKqeY8b62p8ais2e9E= +github.com/prometheus/client_model v0.6.1/go.mod h1:OrxVMOVHjw3lKMa8+x6HeMGkHMQyHDk9E3jmP2AmGiY= github.com/prometheus/common v0.0.0-20180110214958-89604d197083/go.mod h1:daVV7qP5qjZbuso7PdcryaAu0sAZbrN9i7WWcTMWvro= github.com/prometheus/common v0.0.0-20181113130724-41aa239b4cce/go.mod h1:daVV7qP5qjZbuso7PdcryaAu0sAZbrN9i7WWcTMWvro= github.com/prometheus/common v0.4.0/go.mod h1:TNfzLD0ON7rHzMJeJkieUDPYmFC7Snx/y86RQel1bk4= @@ -1879,6 +1914,8 @@ github.com/prometheus/common v0.9.1/go.mod h1:yhUN8i9wzaXS3w1O07YhxHEBxD+W35wd8b github.com/prometheus/common v0.10.0/go.mod h1:Tlit/dnDKsSWFlCLTWaA1cyBgKHSMdTB80sz/V91rCo= github.com/prometheus/common v0.26.0/go.mod h1:M7rCNAaPfAosfx8veZJCuw84e35h3Cfd9VFqTh1DIvc= github.com/prometheus/common v0.30.0/go.mod h1:vu+V0TpY+O6vW9J44gczi3Ap/oXXR10b+M/gUGO4Hls= +github.com/prometheus/common v0.54.0 h1:ZlZy0BgJhTwVZUn7dLOkwCZHUkrAqd3WYtcFCWnM1D8= +github.com/prometheus/common v0.54.0/go.mod h1:/TQgMJP5CuVYveyT7n/0Ix8yLNNXy9yRSkhnLTHPDIQ= github.com/prometheus/procfs v0.0.0-20180125133057-cb4147076ac7/go.mod h1:c3At6R/oaqEKCNdg8wHV1ftS6bRYblBhIjjI8uT2IGk= github.com/prometheus/procfs v0.0.0-20181005140218-185b4288413d/go.mod h1:c3At6R/oaqEKCNdg8wHV1ftS6bRYblBhIjjI8uT2IGk= github.com/prometheus/procfs v0.0.0-20190507164030-5867b95ac084/go.mod h1:TjEm7ze935MbeOT/UhFTIMYKhuLP4wbCsTZCD3I8kEA= @@ -1891,6 +1928,8 @@ github.com/prometheus/procfs v0.1.3/go.mod h1:lV6e/gmhEcM9IjHGsFOCxxuZ+z1YqCvr4O github.com/prometheus/procfs v0.2.0/go.mod h1:lV6e/gmhEcM9IjHGsFOCxxuZ+z1YqCvr4OA4YeYWdaU= github.com/prometheus/procfs v0.6.0/go.mod h1:cz+aTbrPOrUb4q7XlbU9ygM+/jj0fzG6c1xBZuNvfVA= github.com/prometheus/procfs v0.7.3/go.mod h1:cz+aTbrPOrUb4q7XlbU9ygM+/jj0fzG6c1xBZuNvfVA= +github.com/prometheus/procfs v0.15.0 h1:A82kmvXJq2jTu5YUhSGNlYoxh85zLnKgPz4bMZgI5Ek= +github.com/prometheus/procfs v0.15.0/go.mod h1:Y0RJ/Y5g5wJpkTisOtqwDSo4HwhGmLB4VQSw2sQJLHk= github.com/prometheus/tsdb v0.7.1/go.mod h1:qhTCs0VvXwvX/y3TZrWD7rabWM+ijKTux40TwIPHuXU= github.com/rcrowley/go-metrics v0.0.0-20201227073835-cf1acfcdf475 h1:N/ElC8H3+5XpJzTSTfLsJV/mx9Q9g7kxmchpfZyxgzM= github.com/rcrowley/go-metrics v0.0.0-20201227073835-cf1acfcdf475/go.mod h1:bCqnVzQkZxMG4s8nGwiZ5l3QUCyqpo9Y+/ZMZ9VjZe4= @@ -1910,8 +1949,9 @@ github.com/rogpeppe/fastuuid v1.2.0/go.mod h1:jVj6XXZzXRy/MSR5jhDC/2q6DgLz+nrA6L github.com/rogpeppe/go-internal v1.3.0/go.mod h1:M8bDsm7K2OlrFYOpmOWEs/qY81heoFRclV5y23lUDJ4= github.com/rogpeppe/go-internal v1.6.1/go.mod h1:xXDCJY+GAPziupqXw64V24skbSoqbTEfhy4qGm1nDQc= github.com/rogpeppe/go-internal v1.8.0/go.mod h1:WmiCO8CzOY8rg0OYDC4/i/2WRWAB6poM+XZ2dLUbcbE= -github.com/rogpeppe/go-internal v1.9.0 h1:73kH8U+JUqXU8lRuOHeVHaa/SZPifC7BkcraZVejAe8= github.com/rogpeppe/go-internal v1.9.0/go.mod h1:WtVeX8xhTBvf0smdhujwtBcq4Qrzq/fJaraNFVN+nFs= +github.com/rogpeppe/go-internal v1.10.0 h1:TMyTOH3F/DB16zRVcYyreMH6GnZZrwQVAoYjRBZyWFQ= +github.com/rogpeppe/go-internal v1.10.0/go.mod h1:UQnix2H7Ngw/k4C5ijL5+65zddjncjaFoBhdsK/akog= github.com/russross/blackfriday/v2 v2.0.1/go.mod h1:+Rmxgy9KzJVeS9/2gXHxylqXiyQDYRxCVz55jmeOWTM= github.com/ruudk/golang-pdf417 v0.0.0-20181029194003-1af4ab5afa58/go.mod h1:6lfFZQK844Gfx8o5WFuvpxWRwnSoipWe/p622j1v06w= github.com/ruudk/golang-pdf417 v0.0.0-20201230142125-a7e3863a1245/go.mod h1:pQAZKsJ8yyVxGRWYNEm9oFB8ieLgKFnamEyDmSA0BRk= @@ -1937,6 +1977,12 @@ github.com/segmentio/kafka-go v0.4.42 h1:qffhBZCz4WcWyNuHEclHjIMLs2slp6mZO8px+5W github.com/segmentio/kafka-go v0.4.42/go.mod h1:d0g15xPMqoUookug0OU75DhGZxXwCFxSLeJ4uphwJzg= github.com/sergi/go-diff v1.3.1 h1:xkr+Oxo4BOQKmkn/B9eMK0g5Kg/983T9DqqPHwYqD+8= github.com/sergi/go-diff v1.3.1/go.mod h1:aMJSSKb2lpPvRNec0+w3fl7LP9IOFzdc9Pa4NFbPK1I= +github.com/shirou/gopsutil/v3 v3.24.4 h1:dEHgzZXt4LMNm+oYELpzl9YCqV65Yr/6SfrvgRBtXeU= +github.com/shirou/gopsutil/v3 v3.24.4/go.mod h1:lTd2mdiOspcqLgAnr9/nGi71NkeMpWKdmhuxm9GusH8= +github.com/shoenig/go-m1cpu v0.1.6 h1:nxdKQNcEB6vzgA2E2bvzKIYRuNj7XNJ4S/aRSwKzFtM= +github.com/shoenig/go-m1cpu v0.1.6/go.mod h1:1JJMcUBvfNwpq05QDQVAnx3gUHr9IYF7GNg9SUEw2VQ= +github.com/shoenig/test v0.6.4 h1:kVTaSd7WLz5WZ2IaoM0RSzRsUD+m8wRR+5qvntpn4LU= +github.com/shoenig/test v0.6.4/go.mod h1:byHiCGXqrVaflBLAMq/srcZIHynQPQgeyvkvXnjqq0k= github.com/shurcooL/sanitized_anchor_name v1.0.0/go.mod h1:1NzhyTcUVG4SuEtjjoZeVRXNmyL/1OwPU0+IJeTBvfc= github.com/sirupsen/logrus v1.0.4-0.20170822132746-89742aefa4b2/go.mod h1:pMByvHTf9Beacp5x1UXfOR9xyW/9antXMhjMPG0dEzc= github.com/sirupsen/logrus v1.0.6/go.mod h1:pMByvHTf9Beacp5x1UXfOR9xyW/9antXMhjMPG0dEzc= @@ -2035,6 +2081,10 @@ github.com/tidwall/tinyqueue v0.1.1 h1:SpNEvEggbpyN5DIReaJ2/1ndroY8iyEGxPYxoSaym github.com/tidwall/tinyqueue v0.1.1/go.mod h1:O/QNHwrnjqr6IHItYrzoHAKYhBkLI67Q096fQP5zMYw= github.com/tinylib/msgp v1.1.8 h1:FCXC1xanKO4I8plpHGH2P7koL/RzZs12l/+r7vakfm0= github.com/tinylib/msgp v1.1.8/go.mod h1:qkpG+2ldGg4xRFmx+jfTvZPxfGFhi64BcnL9vkCm/Tw= +github.com/tklauser/go-sysconf v0.3.12 h1:0QaGUFOdQaIVdPgfITYzaTegZvdCjmYO52cSFAEVmqU= +github.com/tklauser/go-sysconf v0.3.12/go.mod h1:Ho14jnntGE1fpdOqQEEaiKRpvIavV0hSfmBq8nJbHYI= +github.com/tklauser/numcpus v0.6.1 h1:ng9scYS7az0Bk4OZLvrNXNSAO2Pxr1XXRAPyjhIx+Fk= +github.com/tklauser/numcpus v0.6.1/go.mod h1:1XfjsgE2zo8GVw7POkMbHENHzVg3GzmoZ9fESEdAacY= github.com/tmc/grpc-websocket-proxy v0.0.0-20170815181823-89b8d40f7ca8/go.mod h1:ncp9v5uamzpCO7NfCPTXjqaC+bZgJeR0sMTm6dMHP7U= github.com/tmc/grpc-websocket-proxy v0.0.0-20190109142713-0ad062ec5ee5/go.mod h1:ncp9v5uamzpCO7NfCPTXjqaC+bZgJeR0sMTm6dMHP7U= github.com/tmc/grpc-websocket-proxy v0.0.0-20201229170055-e5319fda7802/go.mod h1:ncp9v5uamzpCO7NfCPTXjqaC+bZgJeR0sMTm6dMHP7U= @@ -2080,6 +2130,8 @@ github.com/vishvananda/netns v0.0.0-20200728191858-db3c7e526aae/go.mod h1:DD4vA1 github.com/vishvananda/netns v0.0.0-20210104183010-2eb08e3e575f/go.mod h1:DD4vA1DwXk04H54A1oHXtwZmA0grkVMdPxx/VGLCah0= github.com/vmihailenco/bufpool v0.1.11 h1:gOq2WmBrq0i2yW5QJ16ykccQ4wH9UyEsgLm6czKAd94= github.com/vmihailenco/bufpool v0.1.11/go.mod h1:AFf/MOy3l2CFTKbxwt0mp2MwnqjNEs5H/UxrkA5jxTQ= +github.com/vmihailenco/msgpack/v4 v4.3.12 h1:07s4sz9IReOgdikxLTKNbBdqDMLsjPKXwvCazn8G65U= +github.com/vmihailenco/msgpack/v4 v4.3.12/go.mod h1:gborTTJjAo/GWTqqRjrLCn9pgNN+NXzzngzBKDPIqw4= github.com/vmihailenco/msgpack/v5 v5.3.4/go.mod h1:7xyJ9e+0+9SaZT0Wt1RGleJXzli6Q/V5KbhBonMG9jc= github.com/vmihailenco/msgpack/v5 v5.4.1 h1:cQriyiUvjTwOHg8QZaPihLWeRAAVoCpE00IUPn0Bjt8= github.com/vmihailenco/msgpack/v5 v5.4.1/go.mod h1:GaZTsDaehaPpQVyxrf5mtQlH+pc21PIudVV/E3rRQok= @@ -2109,6 +2161,8 @@ github.com/yuin/goldmark v1.2.1/go.mod h1:3hX8gzYuyVAZsxl0MRgGTJEmQBFcNTphYh9dec github.com/yuin/goldmark v1.3.5/go.mod h1:mwnBkeHKe2W/ZEtQ+71ViKU8L12m81fl3OWwC1Zlc8k= github.com/yuin/goldmark v1.4.1/go.mod h1:mwnBkeHKe2W/ZEtQ+71ViKU8L12m81fl3OWwC1Zlc8k= github.com/yuin/goldmark v1.4.13/go.mod h1:6yULJ656Px+3vBD8DxQVa3kxgyrAnzto9xy5taEt/CY= +github.com/yusufpapurcu/wmi v1.2.4 h1:zFUKzehAFReQwLys1b/iSMl+JQGSCSjtVqQn9bBrPo0= +github.com/yusufpapurcu/wmi v1.2.4/go.mod h1:SBZ9tNy3G9/m5Oi98Zks0QjeHVDvuK0qfxQmPyzfmi0= github.com/yvasiyarov/go-metrics v0.0.0-20140926110328-57bccd1ccd43/go.mod h1:aX5oPXxHm3bOH+xeAttToC8pqch2ScQN/JoXYupl6xs= github.com/yvasiyarov/gorelic v0.0.0-20141212073537-a9bba5b9ab50/go.mod h1:NUSPSUX/bi6SeDMUh6brw0nXpxHnc96TguQh0+r/ssA= github.com/yvasiyarov/newrelic_platform_go v0.0.0-20140908184405-b21fdbd4370f/go.mod h1:GlGEuHIJweS1mbCqG+7vt2nvWLzLLnRHbXz5JKd/Qbg= @@ -2116,6 +2170,8 @@ github.com/zeebo/assert v1.3.0/go.mod h1:Pq9JiuJQpG8JLJdtkwrJESF0Foym2/D9XMU5ciN github.com/zeebo/xxh3 v1.0.2/go.mod h1:5NWz9Sef7zIDm2JHfFlcQvNekmcEl9ekUZQQKCYaDcA= github.com/zenazn/goji v1.0.1 h1:4lbD8Mx2h7IvloP7r2C0D6ltZP6Ufip8Hn0wmSK5LR8= github.com/zenazn/goji v1.0.1/go.mod h1:7S9M489iMyHBNxwZnk9/EHS098H4/F6TATF2mIxtB1Q= +go.einride.tech/aip v0.66.0 h1:XfV+NQX6L7EOYK11yoHHFtndeaWh3KbD9/cN/6iWEt8= +go.einride.tech/aip v0.66.0/go.mod h1:qAhMsfT7plxBX+Oy7Huol6YUvZ0ZzdUz26yZsQwfl1M= go.etcd.io/bbolt v1.3.2/go.mod h1:IbVyRI1SCnLcuJnV2u8VeU0CEYM7e686BmAb1XKL+uU= go.etcd.io/bbolt v1.3.3/go.mod h1:IbVyRI1SCnLcuJnV2u8VeU0CEYM7e686BmAb1XKL+uU= go.etcd.io/bbolt v1.3.5/go.mod h1:G5EMThwa9y8QZGBClrRx5EY+Yw9kAhnjy3bSjsnlVTQ= @@ -2140,35 +2196,51 @@ go.opencensus.io v0.22.5/go.mod h1:5pWMHQbX5EPX2/62yrJeAkowc+lfs/XD7Uxpq3pI6kk= go.opencensus.io v0.23.0/go.mod h1:XItmlyltB5F7CS4xOC1DcqMoFqwtC6OG2xF7mCv7P7E= go.opencensus.io v0.24.0 h1:y73uSU6J157QMP2kn2r30vwW1A2W2WFwSCGnAVxeaD0= go.opencensus.io v0.24.0/go.mod h1:vNK8G9p7aAivkbmorf4v+7Hgx+Zs0yY+0fOtgBfjQKo= +go.opentelemetry.io/collector/component v0.104.0 h1:jqu/X9rnv8ha0RNZ1a9+x7OU49KwSMsPbOuIEykHuQE= +go.opentelemetry.io/collector/component v0.104.0/go.mod h1:1C7C0hMVSbXyY1ycCmaMUAR9fVwpgyiNQqxXtEWhVpw= +go.opentelemetry.io/collector/config/configtelemetry v0.104.0 h1:eHv98XIhapZA8MgTiipvi+FDOXoFhCYOwyKReOt+E4E= +go.opentelemetry.io/collector/config/configtelemetry v0.104.0/go.mod h1:WxWKNVAQJg/Io1nA3xLgn/DWLE/W1QOB2+/Js3ACi40= +go.opentelemetry.io/collector/pdata v1.11.0 h1:rzYyV1zfTQQz1DI9hCiaKyyaczqawN75XO9mdXmR/hE= +go.opentelemetry.io/collector/pdata v1.11.0/go.mod h1:IHxHsp+Jq/xfjORQMDJjSH6jvedOSTOyu3nbxqhWSYE= +go.opentelemetry.io/collector/semconv v0.104.0 h1:dUvajnh+AYJLEW/XOPk0T0BlwltSdi3vrjO7nSOos3k= +go.opentelemetry.io/collector/semconv v0.104.0/go.mod h1:yMVUCNoQPZVq/IPfrHrnntZTWsLf5YGZ7qwKulIl5hw= go.opentelemetry.io/contrib v0.20.0/go.mod h1:G/EtFaa6qaN7+LxqfIAT3GiZa7Wv5DTBUzl5H4LY0Kc= go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.20.0/go.mod h1:oVGt1LRbBOBq1A5BQLlUg9UaU/54aiHw8cgjV3aWZ/E= go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.28.0/go.mod h1:vEhqr0m4eTc+DWxfsXoXue2GBgV2uUwVznkGIHW/e5w= +go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.49.0 h1:4Pp6oUg3+e/6M4C0A/3kJ2VYa++dsWVTtGgLVj5xtHg= +go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.49.0/go.mod h1:Mjt1i1INqiaoZOMGR1RIUJN+i3ChKoFRqzrRQhlkbs0= go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.20.0/go.mod h1:2AboqHi0CiIZU0qwhtUfCYD1GeUzvvIXWNkhDt7ZMG4= -go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.44.0 h1:KfYpVmrjI7JuToy5k8XV3nkapjWx48k4E4JOtVstzQI= -go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.44.0/go.mod h1:SeQhzAEccGVZVEy7aH87Nh0km+utSpo1pTv6eMMop48= +go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.49.0 h1:jq9TW8u3so/bN+JPT166wjOI6/vQPF6Xe7nMNIltagk= +go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.49.0/go.mod h1:p8pYQP+m5XfbZm9fxtSKAbM6oIllS7s2AfxrChvc7iw= go.opentelemetry.io/otel v0.20.0/go.mod h1:Y3ugLH2oa81t5QO+Lty+zXf8zC9L26ax4Nzoxm/dooo= go.opentelemetry.io/otel v1.3.0/go.mod h1:PWIKzi6JCp7sM0k9yZ43VX+T345uNbAkDKwHVjb2PTs= go.opentelemetry.io/otel v1.6.3/go.mod h1:7BgNga5fNlF/iZjG06hM3yofffp0ofKCDwSXx1GC4dI= -go.opentelemetry.io/otel v1.20.0 h1:vsb/ggIY+hUjD/zCAQHpzTmndPqv/ml2ArbsbfBYTAc= -go.opentelemetry.io/otel v1.20.0/go.mod h1:oUIGj3D77RwJdM6PPZImDpSZGDvkD9fhesHny69JFrs= +go.opentelemetry.io/otel v1.27.0 h1:9BZoF3yMK/O1AafMiQTVu0YDj5Ea4hPhxCs7sGva+cg= +go.opentelemetry.io/otel v1.27.0/go.mod h1:DMpAK8fzYRzs+bi3rS5REupisuqTheUlSZJ1WnZaPAQ= go.opentelemetry.io/otel/exporters/otlp v0.20.0/go.mod h1:YIieizyaN77rtLJra0buKiNBOm9XQfkPEKBeuhoMwAM= go.opentelemetry.io/otel/exporters/otlp/internal/retry v1.3.0/go.mod h1:VpP4/RMn8bv8gNo9uK7/IMY4mtWLELsS+JIP0inH0h4= go.opentelemetry.io/otel/exporters/otlp/otlptrace v1.3.0/go.mod h1:hO1KLR7jcKaDDKDkvI9dP/FIhpmna5lkqPUQdEjFAM8= go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracegrpc v1.3.0/go.mod h1:keUU7UfnwWTWpJ+FWnyqmogPa82nuU5VUANFq49hlMY= go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracehttp v1.3.0/go.mod h1:QNX1aly8ehqqX1LEa6YniTU7VY9I6R3X/oPxhGdTceE= +go.opentelemetry.io/otel/exporters/prometheus v0.49.0 h1:Er5I1g/YhfYv9Affk9nJLfH/+qCCVVg1f2R9AbJfqDQ= +go.opentelemetry.io/otel/exporters/prometheus v0.49.0/go.mod h1:KfQ1wpjf3zsHjzP149P4LyAwWRupc6c7t1ZJ9eXpKQM= go.opentelemetry.io/otel/metric v0.20.0/go.mod h1:598I5tYlH1vzBjn+BTuhzTCSb/9debfNp6R3s7Pr1eU= -go.opentelemetry.io/otel/metric v1.20.0 h1:ZlrO8Hu9+GAhnepmRGhSU7/VkpjrNowxRN9GyKR4wzA= -go.opentelemetry.io/otel/metric v1.20.0/go.mod h1:90DRw3nfK4D7Sm/75yQ00gTJxtkBxX+wu6YaNymbpVM= +go.opentelemetry.io/otel/metric v1.27.0 h1:hvj3vdEKyeCi4YaYfNjv2NUje8FqKqUY8IlF0FxV/ik= +go.opentelemetry.io/otel/metric v1.27.0/go.mod h1:mVFgmRlhljgBiuk/MP/oKylr4hs85GZAylncepAX/ak= go.opentelemetry.io/otel/oteltest v0.20.0/go.mod h1:L7bgKf9ZB7qCwT9Up7i9/pn0PWIa9FqQ2IQ8LoxiGnw= go.opentelemetry.io/otel/sdk v0.20.0/go.mod h1:g/IcepuwNsoiX5Byy2nNV0ySUF1em498m7hBWC279Yc= go.opentelemetry.io/otel/sdk v1.3.0/go.mod h1:rIo4suHNhQwBIPg9axF8V9CA72Wz2mKF1teNrup8yzs= +go.opentelemetry.io/otel/sdk v1.27.0 h1:mlk+/Y1gLPLn84U4tI8d3GNJmGT/eXe3ZuOXN9kTWmI= +go.opentelemetry.io/otel/sdk v1.27.0/go.mod h1:Ha9vbLwJE6W86YstIywK2xFfPjbWlCuwPtMkKdz/Y4A= go.opentelemetry.io/otel/sdk/export/metric v0.20.0/go.mod h1:h7RBNMsDJ5pmI1zExLi+bJK+Dr8NQCh0qGhm1KDnNlE= go.opentelemetry.io/otel/sdk/metric v0.20.0/go.mod h1:knxiS8Xd4E/N+ZqKmUPf3gTTZ4/0TjTXukfxjzSTpHE= +go.opentelemetry.io/otel/sdk/metric v1.27.0 h1:5uGNOlpXi+Hbo/DRoI31BSb1v+OGcpv2NemcCrOL8gI= +go.opentelemetry.io/otel/sdk/metric v1.27.0/go.mod h1:we7jJVrYN2kh3mVBlswtPU22K0SA+769l93J6bsyvqw= go.opentelemetry.io/otel/trace v0.20.0/go.mod h1:6GjCW8zgDjwGHGa6GkyeB8+/5vjT16gUEi0Nf1iBdgw= go.opentelemetry.io/otel/trace v1.3.0/go.mod h1:c/VDhno8888bvQYmbYLqe41/Ldmr/KKunbvWM4/fEjk= go.opentelemetry.io/otel/trace v1.6.3/go.mod h1:GNJQusJlUgZl9/TQBPKU/Y/ty+0iVB5fjhKeJGZPGFs= -go.opentelemetry.io/otel/trace v1.20.0 h1:+yxVAPZPbQhbC3OfAkeIVTky6iTFpcr4SiY9om7mXSQ= -go.opentelemetry.io/otel/trace v1.20.0/go.mod h1:HJSK7F/hA5RlzpZ0zKDCHCDHm556LCDtKaAo6JmBFUU= +go.opentelemetry.io/otel/trace v1.27.0 h1:IqYb813p7cmbHk0a5y6pD5JPakbVfftRXABGt5/Rscw= +go.opentelemetry.io/otel/trace v1.27.0/go.mod h1:6RiD1hkAprV4/q+yd2ln1HG9GoPx39SuvvstaLBl+l4= go.opentelemetry.io/proto/otlp v0.7.0/go.mod h1:PqfVotwruBrMGOCsRd/89rSnXhoiJIqeYNgFYFoEGnI= go.opentelemetry.io/proto/otlp v0.11.0/go.mod h1:QpEjXPrNQzrFDZgoTo49dgHR9RYRSrg3NAKnUGl9YpQ= go.opentelemetry.io/proto/otlp v0.15.0/go.mod h1:H7XAot3MsfNsj7EXtrA2q5xSNQ10UqI405h3+duxN4U= @@ -2185,8 +2257,12 @@ go.uber.org/goleak v1.3.0 h1:2K3zAYmnTNqV73imy9J1T3WC+gmCePx2hEGkimedGto= go.uber.org/goleak v1.3.0/go.mod h1:CoHD4mav9JJNrW/WLlf7HGZPjdw8EucARQHekz1X6bE= go.uber.org/multierr v1.1.0/go.mod h1:wR5kodmAFQ0UK8QlbwjlSNy0Z68gJhDJUG5sjR94q/0= go.uber.org/multierr v1.6.0/go.mod h1:cdWPpRnG4AhwMwsgIHip0KRBQjJy5kYEpYjJxpXp9iU= +go.uber.org/multierr v1.11.0 h1:blXXJkSxSSfBVBlC76pxqeO+LN3aDfLQo+309xJstO0= +go.uber.org/multierr v1.11.0/go.mod h1:20+QtiLqy0Nd6FdQB9TLXag12DsQkrbs3htMFfDN80Y= go.uber.org/zap v1.10.0/go.mod h1:vwi/ZaCAaUcBkycHslxD9B2zi4UTXhF60s6SWpuDF0Q= go.uber.org/zap v1.17.0/go.mod h1:MXVU+bhUf/A7Xi2HNOnopQOrmycQ5Ih87HtOu4q5SSo= +go.uber.org/zap v1.27.0 h1:aJMhYGrd5QSmlpLMr2MftRKl7t8J8PTZPA732ud/XR8= +go.uber.org/zap v1.27.0/go.mod h1:GB2qFLM7cTU87MWRP2mPIjqfIDnGu+VIO4V/SdhGo2E= golang.org/x/arch v0.0.0-20210923205945-b76863e36670/go.mod h1:5om86z9Hs0C8fWVUuoMHwpExlXzs5Tkyp9hOrfG7pp8= golang.org/x/arch v0.4.0 h1:A8WCeEWhLwPBKNbFi5Wv5UTCBx5zzubnXDlMOFAzFMc= golang.org/x/arch v0.4.0/go.mod h1:5om86z9Hs0C8fWVUuoMHwpExlXzs5Tkyp9hOrfG7pp8= @@ -2215,7 +2291,6 @@ golang.org/x/crypto v0.0.0-20210421170649-83a5a9bb288b/go.mod h1:T9bdIzuCu7OtxOm golang.org/x/crypto v0.0.0-20210817164053-32db794688a5/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= golang.org/x/crypto v0.0.0-20210921155107-089bfa567519/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= golang.org/x/crypto v0.0.0-20211108221036-ceb1ce70b4fa/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= -golang.org/x/crypto v0.0.0-20220314234659-1baeb1ce4c0b/go.mod h1:IxCIyHEi3zRg3s0A5j5BB6A9Jmi73HwBIUl50j+osU4= golang.org/x/crypto v0.0.0-20220511200225-c6db032c6c88/go.mod h1:IxCIyHEi3zRg3s0A5j5BB6A9Jmi73HwBIUl50j+osU4= golang.org/x/crypto v0.0.0-20220622213112-05595931fe9d/go.mod h1:IxCIyHEi3zRg3s0A5j5BB6A9Jmi73HwBIUl50j+osU4= golang.org/x/crypto v0.0.0-20220829220503-c86fa9a7ed90/go.mod h1:IxCIyHEi3zRg3s0A5j5BB6A9Jmi73HwBIUl50j+osU4= @@ -2224,8 +2299,8 @@ golang.org/x/crypto v0.1.0/go.mod h1:RecgLatLF4+eUMCP1PoPZQb+cVrJcOPbHkTkbkB9sbw golang.org/x/crypto v0.4.0/go.mod h1:3quD/ATkf6oY+rnes5c3ExXTbLc8mueNue5/DoinL80= golang.org/x/crypto v0.6.0/go.mod h1:OFC/31mSvZgRz0V1QTNCzfAI1aIRzbiufJtkMIlEp58= golang.org/x/crypto v0.19.0/go.mod h1:Iy9bg/ha4yyC70EfRS8jz+B6ybOBKMaSxLj6P6oBDfU= -golang.org/x/crypto v0.21.0 h1:X31++rzVUdKhX5sWmSOFZxx8UW/ldWx55cbf08iNAMA= -golang.org/x/crypto v0.21.0/go.mod h1:0BP7YvVV9gBbVKyeTG0Gyn+gZm94bibOW5BjDEYAOMs= +golang.org/x/crypto v0.25.0 h1:ypSNr+bnYL2YhwoMt2zPxHFmbAN1KZs/njMG3hxUp30= +golang.org/x/crypto v0.25.0/go.mod h1:T+wALwcMOSE0kXgUAnPAHqTLW+XHgcELELW8VaDgm/M= golang.org/x/exp v0.0.0-20180321215751-8460e604b9de/go.mod h1:CJ0aWSM057203Lf6IL+f9T1iT9GByDxfZKAQTCR3kQA= golang.org/x/exp v0.0.0-20180807140117-3d87b88a115f/go.mod h1:CJ0aWSM057203Lf6IL+f9T1iT9GByDxfZKAQTCR3kQA= golang.org/x/exp v0.0.0-20190121172915-509febef88a4/go.mod h1:CJ0aWSM057203Lf6IL+f9T1iT9GByDxfZKAQTCR3kQA= @@ -2284,8 +2359,8 @@ golang.org/x/mod v0.5.1/go.mod h1:5OXOZSfqPIIbmVBIIKWRFfZjPR0E5r58TLhUjH0a2Ro= golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91VN4djpZkiMVwK6gcyfeH4XE8wZrZaV4= golang.org/x/mod v0.7.0/go.mod h1:iBbtSCu2XBx23ZKBPSOrRkjjQPZFPuis4dIYUhu/chs= golang.org/x/mod v0.8.0/go.mod h1:iBbtSCu2XBx23ZKBPSOrRkjjQPZFPuis4dIYUhu/chs= -golang.org/x/mod v0.14.0 h1:dGoOF9QVLYng8IHTm7BAyWqCqSheQ5pYWGhzW00YJr0= -golang.org/x/mod v0.14.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= +golang.org/x/mod v0.20.0 h1:utOm6MM3R3dnawAiJgn0y+xvuYRsm1RKM/4giyfDgV0= +golang.org/x/mod v0.20.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20180218175443-cbe0f9307d01/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20180724234803-3673e40ba225/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= golang.org/x/net v0.0.0-20180826012351-8a410e7b638d/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= @@ -2371,8 +2446,8 @@ golang.org/x/net v0.6.0/go.mod h1:2Tu9+aMcznHK/AK1HMvgo6xiTLG5rD5rZLDS+rp2Bjs= golang.org/x/net v0.7.0/go.mod h1:2Tu9+aMcznHK/AK1HMvgo6xiTLG5rD5rZLDS+rp2Bjs= golang.org/x/net v0.8.0/go.mod h1:QVkue5JL9kW//ek3r6jTKnTFis1tRmNAW2P1shuFdJc= golang.org/x/net v0.10.0/go.mod h1:0qNGK6F8kojg2nk9dLZ2mShWaEBan6FAoqfSigmmuDg= -golang.org/x/net v0.23.0 h1:7EYJ93RZ9vYSZAIb2x3lnuvqO5zneoD6IvWjuhfxjTs= -golang.org/x/net v0.23.0/go.mod h1:JKghWKKOSdJwpW2GEx0Ja7fmaKnMsbu+MWVZTokSYmg= +golang.org/x/net v0.27.0 h1:5K3Njcw06/l2y9vpGCSdcxWOYHOUk3dVNGDXN+FvAys= +golang.org/x/net v0.27.0/go.mod h1:dDi0PyhWNoiUOrAS8uXv/vnScO4wnHQO4mj9fn/RytE= golang.org/x/oauth2 v0.0.0-20180821212333-d2e6202438be/go.mod h1:N/0e6XlmueqKjAGxoOufVs8QHGRruUQn6yWY3a++T0U= golang.org/x/oauth2 v0.0.0-20190226205417-e64efc72b421/go.mod h1:gOpvHmFTYa4IltrdGE7lF6nIHvwfUNPOp7c8zoXwtLw= golang.org/x/oauth2 v0.0.0-20190604053449-0f29369cfe45/go.mod h1:gOpvHmFTYa4IltrdGE7lF6nIHvwfUNPOp7c8zoXwtLw= @@ -2401,8 +2476,8 @@ golang.org/x/oauth2 v0.0.0-20221014153046-6fdb5e3db783/go.mod h1:h4gKUeWbJ4rQPri golang.org/x/oauth2 v0.4.0/go.mod h1:RznEsdpjGAINPTOF0UH/t+xJ75L18YO3Ho6Pyn+uRec= golang.org/x/oauth2 v0.5.0/go.mod h1:9/XBHVqLaWO3/BRHs5jbpYCnOZVjj5V0ndyaAM7KB4I= golang.org/x/oauth2 v0.6.0/go.mod h1:ycmewcwgD4Rpr3eZJLSB4Kyyljb3qDh40vJ8STE5HKw= -golang.org/x/oauth2 v0.9.0 h1:BPpt2kU7oMRq3kCHAA1tbSEshXRw1LpG2ztgDwrzuAs= -golang.org/x/oauth2 v0.9.0/go.mod h1:qYgFZaFiu6Wg24azG8bdV52QJXJGbZzIIsRCdVKzbLw= +golang.org/x/oauth2 v0.18.0 h1:09qnuIAgzdx1XplqJvW6CQqMCtGZykZWcXzPMPUusvI= +golang.org/x/oauth2 v0.18.0/go.mod h1:Wf7knwG0MPoWIMMBgFlEaSUDaKskp0dCfrlJRJXbBi8= golang.org/x/sync v0.0.0-20180314180146-1d60e4601c6f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20181108010431-42b317875d0f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20181221193216-37e7f081c4d4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= @@ -2420,8 +2495,8 @@ golang.org/x/sync v0.0.0-20220819030929-7fc1605a5dde/go.mod h1:RxMgew5VJxzue5/jJ golang.org/x/sync v0.0.0-20220923202941-7f9b1623fab7/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20220929204114-8fcdb60fdcc0/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.1.0/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= -golang.org/x/sync v0.5.0 h1:60k92dhOjHxJkrqnwsfl8KuaHbn/5dl0lUPUklKo3qE= -golang.org/x/sync v0.5.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= +golang.org/x/sync v0.8.0 h1:3NFvSEYkUoMifnESzZl15y791HH1qU2xm6eCJU5ZPXQ= +golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20180823144017-11551d06cbcc/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20180830151530-49385e6e1522/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20180905080454-ebe1bf3edb33/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= @@ -2498,6 +2573,7 @@ golang.org/x/sys v0.0.0-20201117170446-d9b008d0a637/go.mod h1:h1NjWce9XRLGQEsW7w golang.org/x/sys v0.0.0-20201119102817-f84b799fce68/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20201201145000-ef89a241ccb3/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20201202213521-69691e467435/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20201204225414-ed752295db88/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210104204734-6f8348627aad/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210112080510-489259a85091/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210119212857-b64e53b001e4/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= @@ -2566,9 +2642,11 @@ golang.org/x/sys v0.4.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.5.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.6.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.8.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= +golang.org/x/sys v0.11.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.17.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= -golang.org/x/sys v0.20.0 h1:Od9JTbYCk261bKm4M/mw7AklTlFYIa0bIp9BgSm1S8Y= -golang.org/x/sys v0.20.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.19.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.23.0 h1:YfKFowiIMvtgl1UERQoTPPToxltDeZfbj4H7dVUCwmM= +golang.org/x/sys v0.23.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201117132131-f5c789dd3221/go.mod h1:Nr5EML6q2oocZ2LXRh80K7BxOlk5/8JxuGnuhpl+muw= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210220032956-6a3ed077a48d/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= @@ -2583,8 +2661,8 @@ golang.org/x/term v0.5.0/go.mod h1:jMB1sMXY+tzblOD4FWmEbocvup2/aLOaQEp7JmGp78k= golang.org/x/term v0.6.0/go.mod h1:m6U89DPEgQRMq3DNkDClhWw02AUbt2daBVO4cn4Hv9U= golang.org/x/term v0.8.0/go.mod h1:xPskH00ivmX89bAKVGSKKtLOWNx2+17Eiy94tnKShWo= golang.org/x/term v0.17.0/go.mod h1:lLRBjIVuehSbZlaOtGMbcMncT+aqLLLmKrsjNrUguwk= -golang.org/x/term v0.18.0 h1:FcHjZXDMxI8mM3nwhX9HlKop4C0YQvCVCdwYl2wOtE8= -golang.org/x/term v0.18.0/go.mod h1:ILwASektA3OnRv7amZ1xhE/KTR+u50pbXfZ03+6Nx58= +golang.org/x/term v0.22.0 h1:BbsgPEJULsl2fV/AT3v15Mjva5yXKQDyKf+TbDz7QJk= +golang.org/x/term v0.22.0/go.mod h1:F3qCibpT5AMpCRfhfT53vVJwhLtIVHhB9XDjfFvnMI4= golang.org/x/text v0.0.0-20170915032832-14c0d48ead0c/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= golang.org/x/text v0.3.1-0.20180807135948-17ff2d5776d2/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= @@ -2601,8 +2679,9 @@ golang.org/x/text v0.6.0/go.mod h1:mrYo+phRRbMaCq/xk9113O4dZlRixOauAjOtrjsXDZ8= golang.org/x/text v0.7.0/go.mod h1:mrYo+phRRbMaCq/xk9113O4dZlRixOauAjOtrjsXDZ8= golang.org/x/text v0.8.0/go.mod h1:e1OnstbJyHTd6l/uOt8jFFHp6TRDWZR/bV3emEE/zU8= golang.org/x/text v0.9.0/go.mod h1:e1OnstbJyHTd6l/uOt8jFFHp6TRDWZR/bV3emEE/zU8= -golang.org/x/text v0.14.0 h1:ScX5w1eTa3QqT8oi6+ziP7dTV1S2+ALU0bI+0zXKWiQ= golang.org/x/text v0.14.0/go.mod h1:18ZOQIKpY8NJVqYksKHtTdi31H5itFRjB5/qKTNYzSU= +golang.org/x/text v0.16.0 h1:a94ExnEXNtEwYLGJSIUxnWoxoRz/ZcCsV63ROupILh4= +golang.org/x/text v0.16.0/go.mod h1:GhwF1Be+LQoKShO3cGOHzqOgRrGaYc9AvblQOmPVHnI= golang.org/x/time v0.0.0-20180412165947-fbb02b2291d2/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= golang.org/x/time v0.0.0-20181108054448-85acf8d2951c/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= golang.org/x/time v0.0.0-20190308202827-9d24e82272b4/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= @@ -2613,8 +2692,9 @@ golang.org/x/time v0.0.0-20210220033141-f8bda1e9f3ba/go.mod h1:tRJNPiyCQ0inRvYxb golang.org/x/time v0.0.0-20210723032227-1f47c861a9ac/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= golang.org/x/time v0.0.0-20220922220347-f3bd1da661af/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= golang.org/x/time v0.1.0/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= -golang.org/x/time v0.3.0 h1:rg5rLMjNzMS1RkNLzCG38eapWhnYLFYXDXj2gOlr8j4= golang.org/x/time v0.3.0/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= +golang.org/x/time v0.6.0 h1:eTDhh4ZXt5Qf0augr54TN6suAUudPcawVZeIAPU7D4U= +golang.org/x/time v0.6.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= golang.org/x/tools v0.0.0-20180221164845-07fd8470d635/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20180525024113-a5b4c53f6e8b/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= @@ -2693,8 +2773,8 @@ golang.org/x/tools v0.1.12/go.mod h1:hNGJHUnrk76NpqgfD5Aqm5Crs+Hm0VOH/i9J2+nxYbc golang.org/x/tools v0.3.0/go.mod h1:/rWhSS2+zyEVwoJf8YAX6L2f0ntZ7Kn/mGgAWcipA5k= golang.org/x/tools v0.4.0/go.mod h1:UE5sM2OK9E/d67R0ANs2xJizIymRP5gJU295PvKXxjQ= golang.org/x/tools v0.6.0/go.mod h1:Xwgl3UAJ/d3gWutnCtw505GrjyAbvKui8lOU390QaIU= -golang.org/x/tools v0.16.1 h1:TLyB3WofjdOEepBHAU20JdNC1Zbg87elYofWYAY5oZA= -golang.org/x/tools v0.16.1/go.mod h1:kYVVN6I1mBNoB1OX+noeBjbRk4IUEPa7JJ+TJMEooJ0= +golang.org/x/tools v0.23.0 h1:SGsXPZ+2l4JsgaCKkx+FQ9YZ5XEtA1GZYuoDjenLjvg= +golang.org/x/tools v0.23.0/go.mod h1:pnu6ufv6vQkll6szChhK3C3L/ruaIv5eBeztNG8wtsI= golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191011141410-1b5146add898/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191204190536-9bdfabe68543/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= @@ -2771,16 +2851,17 @@ google.golang.org/api v0.108.0/go.mod h1:2Ts0XTHNVWxypznxWOYUeI4g3WdP9Pk2Qk58+a/ google.golang.org/api v0.110.0/go.mod h1:7FC4Vvx1Mooxh8C5HWjzZHcavuS2f6pmJpZx60ca7iI= google.golang.org/api v0.111.0/go.mod h1:qtFHvU9mhgTJegR31csQ+rwxyUTHOKFqCKWp1J0fdw0= google.golang.org/api v0.114.0/go.mod h1:ifYI2ZsFK6/uGddGfAD5BMxlnkBqCmqHSDUVi45N5Yg= -google.golang.org/api v0.128.0 h1:RjPESny5CnQRn9V6siglged+DZCgfu9l6mO9dkX9VOg= -google.golang.org/api v0.128.0/go.mod h1:Y611qgqaE92On/7g65MQgxYul3c0rEB894kniWLY750= +google.golang.org/api v0.169.0 h1:QwWPy71FgMWqJN/l6jVlFHUa29a7dcUy02I8o799nPY= +google.golang.org/api v0.169.0/go.mod h1:gpNOiMA2tZ4mf5R9Iwf4rK/Dcz0fbdIgWYWVoxmsyLg= google.golang.org/appengine v1.1.0/go.mod h1:EbEs0AVv82hx2wNQdGPgUI5lhzA/G0D9YwlJXL52JkM= google.golang.org/appengine v1.4.0/go.mod h1:xpcJRLb0r/rnEns0DIKYYv+WjYCduHsrkT7/EB5XEv4= google.golang.org/appengine v1.5.0/go.mod h1:xpcJRLb0r/rnEns0DIKYYv+WjYCduHsrkT7/EB5XEv4= google.golang.org/appengine v1.6.1/go.mod h1:i06prIuMbXzDqacNJfV5OdTW448YApPu5ww/cMBSeb0= google.golang.org/appengine v1.6.5/go.mod h1:8WjMMxjGQR8xUklV/ARdw2HLXBOI7O7uCIDZVag1xfc= google.golang.org/appengine v1.6.6/go.mod h1:8WjMMxjGQR8xUklV/ARdw2HLXBOI7O7uCIDZVag1xfc= -google.golang.org/appengine v1.6.7 h1:FZR1q0exgwxzPzp/aF+VccGrSfxfPpkBqjIIEq3ru6c= google.golang.org/appengine v1.6.7/go.mod h1:8WjMMxjGQR8xUklV/ARdw2HLXBOI7O7uCIDZVag1xfc= +google.golang.org/appengine v1.6.8 h1:IhEN5q69dyKagZPYMSdIjS2HqprW324FRQZJcGqPAsM= +google.golang.org/appengine v1.6.8/go.mod h1:1jJ3jBArFh5pcgW8gCtRJnepW8FzD1V44FJffLiz/Ds= google.golang.org/cloud v0.0.0-20151119220103-975617b05ea8/go.mod h1:0H1ncTHf11KCFhTc/+EFRbzSCOZx+VUbRMk55Yv5MYk= google.golang.org/genproto v0.0.0-20180817151627-c66870c02cf8/go.mod h1:JiN7NxoALGmiZfu7CAH4rXhgtRTLTxftemlI0sWmxmc= google.golang.org/genproto v0.0.0-20190307195333-5fe7a883aa19/go.mod h1:VzzqZJRnGkLBvHegQrXjBqPurQTc5/KpmUdxsrq26oE= @@ -2918,12 +2999,12 @@ google.golang.org/genproto v0.0.0-20230303212802-e74f57abe488/go.mod h1:TvhZT5f7 google.golang.org/genproto v0.0.0-20230306155012-7f2fa6fef1f4/go.mod h1:NWraEVixdDnqcqQ30jipen1STv2r/n24Wb7twVTGR4s= google.golang.org/genproto v0.0.0-20230320184635-7606e756e683/go.mod h1:NWraEVixdDnqcqQ30jipen1STv2r/n24Wb7twVTGR4s= google.golang.org/genproto v0.0.0-20230331144136-dcfb400f0633/go.mod h1:UUQDJDOlWu4KYeJZffbWgBkS1YFobzKbLVfK69pe0Ak= -google.golang.org/genproto v0.0.0-20230530153820-e85fd2cbaebc h1:8DyZCyvI8mE1IdLy/60bS+52xfymkE72wv1asokgtao= -google.golang.org/genproto v0.0.0-20230530153820-e85fd2cbaebc/go.mod h1:xZnkP7mREFX5MORlOPEzLMr+90PPZQ2QWzrVTWfAq64= -google.golang.org/genproto/googleapis/api v0.0.0-20230530153820-e85fd2cbaebc h1:kVKPf/IiYSBWEWtkIn6wZXwWGCnLKcC8oWfZvXjsGnM= -google.golang.org/genproto/googleapis/api v0.0.0-20230530153820-e85fd2cbaebc/go.mod h1:vHYtlOoi6TsQ3Uk2yxR7NI5z8uoV+3pZtR4jmHIkRig= -google.golang.org/genproto/googleapis/rpc v0.0.0-20230530153820-e85fd2cbaebc h1:XSJ8Vk1SWuNr8S18z1NZSziL0CPIXLCCMDOEFtHBOFc= -google.golang.org/genproto/googleapis/rpc v0.0.0-20230530153820-e85fd2cbaebc/go.mod h1:66JfowdXAEgad5O9NnYcsNPLCPZJD++2L9X0PCMODrA= +google.golang.org/genproto v0.0.0-20240213162025-012b6fc9bca9 h1:9+tzLLstTlPTRyJTh+ah5wIMsBW5c4tQwGTN3thOW9Y= +google.golang.org/genproto v0.0.0-20240213162025-012b6fc9bca9/go.mod h1:mqHbVIp48Muh7Ywss/AD6I5kNVKZMmAa/QEW58Gxp2s= +google.golang.org/genproto/googleapis/api v0.0.0-20240318140521-94a12d6c2237 h1:RFiFrvy37/mpSpdySBDrUdipW/dHwsRwh3J3+A9VgT4= +google.golang.org/genproto/googleapis/api v0.0.0-20240318140521-94a12d6c2237/go.mod h1:Z5Iiy3jtmioajWHDGFk7CeugTyHtPvMHA4UTmUkyalE= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 h1:Q2RxlXqh1cgzzUgV261vBO2jI5R/3DD1J2pM0nI4NhU= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5/go.mod h1:EfXuqaE1J41VCDicxHzUDm+8rk+7ZdXzHV0IhO/I6s0= google.golang.org/grpc v0.0.0-20160317175043-d3ddb4469d5a/go.mod h1:yo6s7OP7yaDglbqo1J04qKzAhqBH6lvTonzMVmEdcZw= google.golang.org/grpc v1.19.0/go.mod h1:mqu4LbDTu4XGKhr4mRzUsmM4RtVoemTSY81AxZiDr8c= google.golang.org/grpc v1.20.1/go.mod h1:10oTOabMzJvdu6/UiuZezV6QK5dSlG84ov/aaiqXj38= @@ -2968,8 +3049,8 @@ google.golang.org/grpc v1.50.1/go.mod h1:ZgQEeidpAuNRZ8iRrlBKXZQP1ghovWIVhdJRyCD google.golang.org/grpc v1.51.0/go.mod h1:wgNDFcnuBGmxLKI/qn4T+m5BtEBYXJPvibbUPsAIPww= google.golang.org/grpc v1.53.0/go.mod h1:OnIrk0ipVdj4N5d9IUoFUx72/VlD7+jUsHwZgwSMQpw= google.golang.org/grpc v1.54.0/go.mod h1:PUSEXI6iWghWaB6lXM4knEgpJNu2qUcKfDtNci3EC2g= -google.golang.org/grpc v1.57.1 h1:upNTNqv0ES+2ZOOqACwVtS3Il8M12/+Hz41RCPzAjQg= -google.golang.org/grpc v1.57.1/go.mod h1:Sd+9RMTACXwmub0zcNY2c4arhtrbBYD1AUHI/dt16Mo= +google.golang.org/grpc v1.64.0 h1:KH3VH9y/MgNQg1dE7b3XfVK0GsPSIzJwdF617gUSbvY= +google.golang.org/grpc v1.64.0/go.mod h1:oxjF8E3FBnjp+/gVFYdWacaLDx9na1aqy9oovLpxQYg= google.golang.org/grpc/cmd/protoc-gen-go-grpc v1.1.0/go.mod h1:6Kw0yEErY5E/yWrBtf03jp27GLLJujG4z/JK95pnjjw= google.golang.org/protobuf v0.0.0-20200109180630-ec00e32a8dfd/go.mod h1:DFci5gLYBciE7Vtevhsrf46CRTquxDuWsQurQQe4oz8= google.golang.org/protobuf v0.0.0-20200221191635-4d8936d0db64/go.mod h1:kwYJMbMJ01Woi6D6+Kah6886xMZcty6N08ah7+eCXa0= @@ -2988,8 +3069,9 @@ google.golang.org/protobuf v1.28.0/go.mod h1:HV8QOd/L58Z+nl8r43ehVNZIU/HEI6OcFqw google.golang.org/protobuf v1.28.1/go.mod h1:HV8QOd/L58Z+nl8r43ehVNZIU/HEI6OcFqwMG9pJV4I= google.golang.org/protobuf v1.29.1/go.mod h1:HV8QOd/L58Z+nl8r43ehVNZIU/HEI6OcFqwMG9pJV4I= google.golang.org/protobuf v1.30.0/go.mod h1:HV8QOd/L58Z+nl8r43ehVNZIU/HEI6OcFqwMG9pJV4I= -google.golang.org/protobuf v1.33.0 h1:uNO2rsAINq/JlFpSdYEKIZ0uKD/R9cpdv0T+yoGwGmI= google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= +google.golang.org/protobuf v1.34.2 h1:6xV6lTsCfpGD21XK49h7MhtcApnLqkfYgPcdHftf6hg= +google.golang.org/protobuf v1.34.2/go.mod h1:qYOHts0dSfpeUzUFpOMr/WGzszTmLH+DiWniOlNbLDw= gopkg.in/airbrake/gobrake.v2 v2.0.9/go.mod h1:/h5ZAUhDkGaJfjzjKLSjv6zCL6O0LLBxU4K+aSYdM/U= gopkg.in/alecthomas/kingpin.v2 v2.2.6/go.mod h1:FMv+mEhP44yOT+4EoQTLFTRgOQ1FBLkstjWtayDeSgw= gopkg.in/avro.v0 v0.0.0-20171217001914-a730b5802183/go.mod h1:FvqrFXt+jCsyQibeRv4xxEJBL5iG2DDW5aeJwzDiq4A= @@ -3009,6 +3091,8 @@ gopkg.in/httprequest.v1 v1.2.1/go.mod h1:x2Otw96yda5+8+6ZeWwHIJTFkEHWP/qP8pJOzqE gopkg.in/inf.v0 v0.9.1 h1:73M5CoZyi3ZLMOyDlQh031Cx6N9NDJ2Vvfl76EDAgDc= gopkg.in/inf.v0 v0.9.1/go.mod h1:cWUDdTG/fYaXco+Dcufb5Vnc6Gp2YChqWtbxRZE0mXw= gopkg.in/ini.v1 v1.51.0/go.mod h1:pNLf8WUiyNEtQjuu5G5vTm06TEv9tsIgeAvK8hOrP4k= +gopkg.in/ini.v1 v1.67.0 h1:Dgnx+6+nfE+IfzjUEISNeydPJh9AXNNsWbGP9KzCsOA= +gopkg.in/ini.v1 v1.67.0/go.mod h1:pNLf8WUiyNEtQjuu5G5vTm06TEv9tsIgeAvK8hOrP4k= gopkg.in/jinzhu/gorm.v1 v1.9.2 h1:sTqyEcgrxG68jdeUXA9syQHNdeRhhfaYZ+vcL3x730I= gopkg.in/jinzhu/gorm.v1 v1.9.2/go.mod h1:56JJPUzbikvTVnoyP1nppSkbJ2L8sunqTBDY2fDrmFg= gopkg.in/mgo.v2 v2.0.0-20190816093944-a6b53ec6cb22/go.mod h1:yeKp02qBN3iKW1OzL3MGk2IdtZzaj7SFntXj72NppTA= @@ -3053,11 +3137,14 @@ gorm.io/gorm v1.24.0/go.mod h1:DVrVomtaYTbqs7gB/x2uVvqnXzv0nqjB396B8cG4dBA= gorm.io/gorm v1.24.2/go.mod h1:DVrVomtaYTbqs7gB/x2uVvqnXzv0nqjB396B8cG4dBA= gorm.io/gorm v1.25.3 h1:zi4rHZj1anhZS2EuEODMhDisGy+Daq9jtPrNGgbQYD8= gorm.io/gorm v1.25.3/go.mod h1:L4uxeKpfBml98NYqVqwAdmV1a2nBtAec/cf3fpucW/k= +gotest.tools v2.2.0+incompatible h1:VsBPFP1AI068pPrMxtb/S8Zkgf9xEmTLJjfM+P5UIEo= gotest.tools v2.2.0+incompatible/go.mod h1:DsYFclhRJ6vuDpmuTbkuFWG+y2sxOXAzmJt81HFBacw= gotest.tools/gotestsum v1.8.2/go.mod h1:6JHCiN6TEjA7Kaz23q1bH0e2Dc3YJjDUZ0DmctFZf+w= gotest.tools/v3 v3.0.2/go.mod h1:3SzNCllyD9/Y+b5r9JIKQ474KzkZyqLqEfYqMsX94Bk= gotest.tools/v3 v3.0.3/go.mod h1:Z7Lb0S5l+klDB31fvDQX8ss/FlKDxtlFlw3Oa8Ymbl8= gotest.tools/v3 v3.3.0/go.mod h1:Mcr9QNxkg0uMvy/YElmo4SpXgJKWgQvYrT7Kw5RzJ1A= +gotest.tools/v3 v3.5.1 h1:EENdUnS3pdur5nybKYIh2Vfgc8IUNBjxDPSjtiJcOzU= +gotest.tools/v3 v3.5.1/go.mod h1:isy3WKz7GK6uNw/sbHzfKBLvlvXwUyV06n6brMxxopU= honnef.co/go/tools v0.0.0-20190102054323-c2f93a96b099/go.mod h1:rf3lG4BRIbNafJWhAfAdb/ePZxsR/4RtNHQocxwk9r4= honnef.co/go/tools v0.0.0-20190106161140-3f1c8253044a/go.mod h1:rf3lG4BRIbNafJWhAfAdb/ePZxsR/4RtNHQocxwk9r4= honnef.co/go/tools v0.0.0-20190418001031-e561f6794a2a/go.mod h1:rf3lG4BRIbNafJWhAfAdb/ePZxsR/4RtNHQocxwk9r4= @@ -3077,8 +3164,8 @@ k8s.io/apimachinery v0.20.4/go.mod h1:WlLqWAHZGg07AeltaI0MV5uk1Omp8xaN0JGLY6gkRp k8s.io/apimachinery v0.20.6/go.mod h1:ejZXtW1Ra6V1O5H8xPBGz+T3+4gfkTCeExAHKU57MAc= k8s.io/apimachinery v0.22.1/go.mod h1:O3oNtNadZdeOMxHFVxOreoznohCpy0z6mocxbZr7oJ0= k8s.io/apimachinery v0.22.5/go.mod h1:xziclGKwuuJ2RM5/rSFQSYAj0zdbci3DH8kj+WvyN0U= -k8s.io/apimachinery v0.23.17 h1:ipJ0SrpI6EzH8zVw0WhCBldgJhzIamiYIumSGTdFExY= -k8s.io/apimachinery v0.23.17/go.mod h1:87v5Wl9qpHbnapX1PSNgln4oO3dlyjAU3NSIwNhT4Lo= +k8s.io/apimachinery v0.25.5 h1:SQomYHvv+aO43qdu3QKRf9YuI0oI8w3RrOQ1qPbAUGY= +k8s.io/apimachinery v0.25.5/go.mod h1:1S2i1QHkmxc8+EZCIxe/fX5hpldVXk4gvnJInMEb8D4= k8s.io/apiserver v0.20.1/go.mod h1:ro5QHeQkgMS7ZGpvf4tSMx6bBOgPfE+f52KwvXfScaU= k8s.io/apiserver v0.20.4/go.mod h1:Mc80thBKOyy7tbvFtB4kJv1kbdD0eIH8k8vianJcbFM= k8s.io/apiserver v0.20.6/go.mod h1:QIJXNt6i6JB+0YQRNcS0hdRHJlMhflFmsBDeSgT1r8Q= @@ -3102,26 +3189,25 @@ k8s.io/cri-api v0.23.1/go.mod h1:REJE3PSU0h/LOV1APBrupxrEJqnoxZC8KWzkBUHwrK4= k8s.io/gengo v0.0.0-20200413195148-3a45101e95ac/go.mod h1:ezvh/TsK7cY6rbqRK0oQQ8IAqLxYwwyPxAX1Pzy0ii0= k8s.io/gengo v0.0.0-20200428234225-8167cfdcfc14/go.mod h1:ezvh/TsK7cY6rbqRK0oQQ8IAqLxYwwyPxAX1Pzy0ii0= k8s.io/gengo v0.0.0-20201113003025-83324d819ded/go.mod h1:FiNAH4ZV3gBg2Kwh89tzAEV2be7d5xI0vBa/VySYy3E= -k8s.io/gengo v0.0.0-20210813121822-485abfe95c7c/go.mod h1:FiNAH4ZV3gBg2Kwh89tzAEV2be7d5xI0vBa/VySYy3E= k8s.io/klog/v2 v2.0.0/go.mod h1:PBfzABfn139FHAV07az/IF9Wp1bkk3vpT2XSJ76fSDE= k8s.io/klog/v2 v2.2.0/go.mod h1:Od+F08eJP+W3HUb4pSrPpgp9DGU4GzlpG/TmITuYh/Y= k8s.io/klog/v2 v2.4.0/go.mod h1:Od+F08eJP+W3HUb4pSrPpgp9DGU4GzlpG/TmITuYh/Y= k8s.io/klog/v2 v2.9.0/go.mod h1:hy9LJ/NvuK+iVyP4Ehqva4HxZG/oXyIS3n3Jmire4Ec= -k8s.io/klog/v2 v2.30.0 h1:bUO6drIvCIsvZ/XFgfxoGFQU/a4Qkh0iAlvUR7vlHJw= k8s.io/klog/v2 v2.30.0/go.mod h1:y1WjHnz7Dj687irZUWR/WLkLc5N1YHtjLdmgWjndZn0= +k8s.io/klog/v2 v2.70.1 h1:7aaoSdahviPmR+XkS7FyxlkkXs6tHISSG03RxleQAVQ= +k8s.io/klog/v2 v2.70.1/go.mod h1:y1WjHnz7Dj687irZUWR/WLkLc5N1YHtjLdmgWjndZn0= k8s.io/kube-openapi v0.0.0-20200805222855-6aeccd4b50c6/go.mod h1:UuqjUnNftUyPE5H64/qeyjQoUZhGpeFDVdxjTeEVN2o= k8s.io/kube-openapi v0.0.0-20201113171705-d219536bb9fd/go.mod h1:WOJ3KddDSol4tAGcJo0Tvi+dK12EcqSLqcWsryKMpfM= k8s.io/kube-openapi v0.0.0-20210421082810-95288971da7e/go.mod h1:vHXdDvt9+2spS2Rx9ql3I8tycm3H9FDfdUoIuKCefvw= k8s.io/kube-openapi v0.0.0-20211109043538-20434351676c/go.mod h1:vHXdDvt9+2spS2Rx9ql3I8tycm3H9FDfdUoIuKCefvw= -k8s.io/kube-openapi v0.0.0-20211115234752-e816edb12b65 h1:E3J9oCLlaobFUqsjG9DfKbP2BmgwBL2p7pn0A3dG9W4= -k8s.io/kube-openapi v0.0.0-20211115234752-e816edb12b65/go.mod h1:sX9MT8g7NVZM5lVL/j8QyCCJe8YSMW30QvGZWaCIDIk= +k8s.io/kube-openapi v0.0.0-20220803162953-67bda5d908f1 h1:MQ8BAZPZlWk3S9K4a9NCkIFQtZShWqoha7snGixVgEA= +k8s.io/kube-openapi v0.0.0-20220803162953-67bda5d908f1/go.mod h1:C/N6wCaBHeBHkHUesQOQy2/MZqGgMAFPqGsGQLdbZBU= k8s.io/kubernetes v1.13.0/go.mod h1:ocZa8+6APFNC2tX1DZASIbocyYT5jHzqFVsY5aoB7Jk= k8s.io/utils v0.0.0-20201110183641-67b214c5f920/go.mod h1:jPW/WVKK9YHAvNhRxK0md/EJ228hCsBRufyofKtW8HA= -k8s.io/utils v0.0.0-20210802155522-efc7438f0176/go.mod h1:jPW/WVKK9YHAvNhRxK0md/EJ228hCsBRufyofKtW8HA= k8s.io/utils v0.0.0-20210819203725-bdf08cb9a70a/go.mod h1:jPW/WVKK9YHAvNhRxK0md/EJ228hCsBRufyofKtW8HA= k8s.io/utils v0.0.0-20210930125809-cb0fa318a74b/go.mod h1:jPW/WVKK9YHAvNhRxK0md/EJ228hCsBRufyofKtW8HA= -k8s.io/utils v0.0.0-20211116205334-6203023598ed h1:ck1fRPWPJWsMd8ZRFsWc6mh/zHp5fZ/shhbrgPUxDAE= -k8s.io/utils v0.0.0-20211116205334-6203023598ed/go.mod h1:jPW/WVKK9YHAvNhRxK0md/EJ228hCsBRufyofKtW8HA= +k8s.io/utils v0.0.0-20220728103510-ee6ede2d64ed h1:jAne/RjBTyawwAy0utX5eqigAwz/lQhTmy+Hr/Cpue4= +k8s.io/utils v0.0.0-20220728103510-ee6ede2d64ed/go.mod h1:jPW/WVKK9YHAvNhRxK0md/EJ228hCsBRufyofKtW8HA= lukechampine.com/uint128 v1.1.1/go.mod h1:c4eWIwlEGaxC/+H1VguhU4PHXNWDCDMUlWdIWl2j1gk= lukechampine.com/uint128 v1.2.0/go.mod h1:c4eWIwlEGaxC/+H1VguhU4PHXNWDCDMUlWdIWl2j1gk= lukechampine.com/uint128 v1.3.0 h1:cDdUVfRwDUDovz610ABgFD17nXD4/uDgVHl2sC3+sbo= @@ -3191,8 +3277,8 @@ rsc.io/sampler v1.3.0/go.mod h1:T1hPZKmBbMNahiBKFy5HrXp6adAjACjK9JXDnKaTXpA= sigs.k8s.io/apiserver-network-proxy/konnectivity-client v0.0.14/go.mod h1:LEScyzhFmoF5pso/YSeBstl57mOzx9xlU9n85RGrDQg= sigs.k8s.io/apiserver-network-proxy/konnectivity-client v0.0.15/go.mod h1:LEScyzhFmoF5pso/YSeBstl57mOzx9xlU9n85RGrDQg= sigs.k8s.io/apiserver-network-proxy/konnectivity-client v0.0.22/go.mod h1:LEScyzhFmoF5pso/YSeBstl57mOzx9xlU9n85RGrDQg= -sigs.k8s.io/json v0.0.0-20211020170558-c049b76a60c6 h1:fD1pz4yfdADVNfFmcP2aBEtudwUQ1AlLnRBALr33v3s= -sigs.k8s.io/json v0.0.0-20211020170558-c049b76a60c6/go.mod h1:p4QtZmO4uMYipTQNzagwnNoseA6OxSUutVw05NhYDRs= +sigs.k8s.io/json v0.0.0-20220713155537-f223a00ba0e2 h1:iXTIw73aPyC+oRdyqqvVJuloN1p0AC/kzH07hu3NE+k= +sigs.k8s.io/json v0.0.0-20220713155537-f223a00ba0e2/go.mod h1:B8JuhiUyNFVKdsE8h686QcCxMaH6HrOAZj4vswFpcB0= sigs.k8s.io/structured-merge-diff/v4 v4.0.1/go.mod h1:bJZC9H9iH24zzfZ/41RGcq60oK1F7G282QMXDPYydCw= sigs.k8s.io/structured-merge-diff/v4 v4.0.2/go.mod h1:bJZC9H9iH24zzfZ/41RGcq60oK1F7G282QMXDPYydCw= sigs.k8s.io/structured-merge-diff/v4 v4.0.3/go.mod h1:bJZC9H9iH24zzfZ/41RGcq60oK1F7G282QMXDPYydCw= diff --git a/internal/apps/go.mod b/internal/apps/go.mod index 2aebc0aee2..456c32649a 100644 --- a/internal/apps/go.mod +++ b/internal/apps/go.mod @@ -1,9 +1,9 @@ module github.com/DataDog/dd-trace-go/internal/apps -go 1.21 +go 1.21.0 require ( - golang.org/x/sync v0.5.0 + golang.org/x/sync v0.8.0 gopkg.in/DataDog/dd-trace-go.v1 v1.64.0 ) @@ -17,29 +17,29 @@ require ( github.com/hashicorp/go-secure-stdlib/strutil v0.1.2 // indirect github.com/hashicorp/go-sockaddr v1.0.2 // indirect github.com/kr/pretty v0.3.0 // indirect - github.com/mitchellh/mapstructure v1.5.0 // indirect + github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c // indirect github.com/outcaste-io/ristretto v0.2.3 // indirect github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2 // indirect github.com/rogpeppe/go-internal v1.8.1 // indirect github.com/ryanuber/go-glob v1.0.0 // indirect go.uber.org/atomic v1.11.0 // indirect - golang.org/x/mod v0.14.0 // indirect - golang.org/x/tools v0.16.1 // indirect + golang.org/x/mod v0.20.0 // indirect + golang.org/x/tools v0.23.0 // indirect gopkg.in/yaml.v3 v3.0.1 // indirect ) require ( - github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 // indirect - github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 // indirect - github.com/DataDog/datadog-go/v5 v5.3.0 // indirect - github.com/DataDog/go-tuf v1.0.2-0.5.2 // indirect + github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-go/v5 v5.5.0 // indirect + github.com/DataDog/go-tuf v1.1.0-0.5.2 // indirect github.com/DataDog/gostackparse v0.7.0 // indirect github.com/DataDog/sketches-go v1.4.5 // indirect github.com/Microsoft/go-winio v0.6.1 // indirect - github.com/cespare/xxhash/v2 v2.2.0 // indirect + github.com/cespare/xxhash/v2 v2.3.0 // indirect github.com/dustin/go-humanize v1.0.1 // indirect github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b // indirect - github.com/google/uuid v1.5.0 // indirect + github.com/google/uuid v1.6.0 // indirect github.com/philhofer/fwd v1.1.2 // indirect github.com/pkg/errors v0.9.1 // indirect github.com/richardartoul/molecule v1.0.1-0.20240531184615-7ca0df43c0b3 // indirect @@ -47,10 +47,10 @@ require ( github.com/spaolacci/murmur3 v1.1.0 // indirect github.com/stretchr/testify v1.9.0 github.com/tinylib/msgp v1.1.8 // indirect - golang.org/x/sys v0.20.0 // indirect - golang.org/x/time v0.3.0 // indirect + golang.org/x/sys v0.23.0 // indirect + golang.org/x/time v0.6.0 // indirect golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 // indirect - google.golang.org/protobuf v1.33.0 // indirect + google.golang.org/protobuf v1.34.2 // indirect ) // use local version of dd-trace-go diff --git a/internal/apps/go.sum b/internal/apps/go.sum index 0e6e942134..a7dd534716 100644 --- a/internal/apps/go.sum +++ b/internal/apps/go.sum @@ -2,14 +2,18 @@ github.com/DataDog/appsec-internal-go v1.7.0 h1:iKRNLih83dJeVya3IoUfK+6HLD/hQsIb github.com/DataDog/appsec-internal-go v1.7.0/go.mod h1:wW0cRfWBo4C044jHGwYiyh5moQV2x0AhnwqMuiX7O/g= github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 h1:bUMSNsw1iofWiju9yc1f+kBd33E3hMJtq9GuU602Iy8= github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0/go.mod h1:HzySONXnAgSmIQfL6gOv9hWprKJkx8CicuXuUbmgWfo= +github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1/go.mod h1:T+qq8YiHRRIuB9A1W1k9KE4Owr9anljl12Ztm7Nx8XU= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 h1:5nE6N3JSs2IG3xzMthNFhXfOaXlrsdgqmJ73lndFf8c= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1/go.mod h1:Vc+snp0Bey4MrrJyiV2tVxxJb6BmLomPvN1RgAvjGaQ= +github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= github.com/DataDog/datadog-go/v5 v5.3.0 h1:2q2qjFOb3RwAZNU+ez27ZVDwErJv5/VpbBPprz7Z+s8= github.com/DataDog/datadog-go/v5 v5.3.0/go.mod h1:XRDJk1pTc00gm+ZDiBKsjh7oOOtJfYfglVCmFb8C2+Q= +github.com/DataDog/datadog-go/v5 v5.5.0/go.mod h1:K9kcYBlxkcPP8tvvjZZKs/m1edNAUFzBbdpTUKfCsuw= github.com/DataDog/go-libddwaf/v3 v3.3.0 h1:jS72fuQpFgJZEdEJDmHJCPAgNTEMZoz1EUvimPUOiJ4= github.com/DataDog/go-libddwaf/v3 v3.3.0/go.mod h1:Bz/0JkpGf689mzbUjKJeheJINqsyyhM8p9PDuHdK2Ec= github.com/DataDog/go-tuf v1.0.2-0.5.2 h1:EeZr937eKAWPxJ26IykAdWA4A0jQXJgkhUjqEI/w7+I= github.com/DataDog/go-tuf v1.0.2-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= +github.com/DataDog/go-tuf v1.1.0-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= github.com/DataDog/gostackparse v0.7.0 h1:i7dLkXHvYzHV308hnkvVGDL3BR4FWl7IsXNPz/IGQh4= github.com/DataDog/gostackparse v0.7.0/go.mod h1:lTfqcJKqS9KnXQGnyQMCugq3u1FP6UZMfWR0aitKFMM= github.com/DataDog/sketches-go v1.4.5 h1:ki7VfeNz7IcNafq7yI/j5U/YCkO3LJiMDtXz9OMQbyE= @@ -22,6 +26,7 @@ github.com/bgentry/speakeasy v0.1.0/go.mod h1:+zsyZBPWlz7T6j88CTgSN5bM796AkVf0kB github.com/cespare/xxhash/v2 v2.1.1/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= github.com/cespare/xxhash/v2 v2.2.0 h1:DC2CZ1Ep5Y4k3ZQ899DldepgrayRUGE6BBZ/cd9Cj44= github.com/cespare/xxhash/v2 v2.2.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= +github.com/cespare/xxhash/v2 v2.3.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= github.com/creack/pty v1.1.9/go.mod h1:oKZEueFk5CKHvIhNR5MUki03XCEU+Q6VDXinZuGJ33E= github.com/davecgh/go-spew v1.1.0/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.1/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= @@ -51,6 +56,7 @@ github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b h1:h9U78+dx9a4BKdQkBB github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b/go.mod h1:czg5+yv1E0ZGTi6S6vVK1mke0fV+FaUhNGcd6VRS9Ik= github.com/google/uuid v1.5.0 h1:1p67kYwdtXjb0gL0BPiP1Av9wiZPo5A8z2cWkTZ+eyU= github.com/google/uuid v1.5.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= +github.com/google/uuid v1.6.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/hashicorp/errwrap v1.0.0/go.mod h1:YH+1FKiLXxHSkmPseP+kNlulaMuP3n2brvKWEqk/Jc4= github.com/hashicorp/go-multierror v1.0.0/go.mod h1:dHtQlpGsu+cZNNAkkCN/P3hoUDHhCYQXV3UM06sGGrk= github.com/hashicorp/go-secure-stdlib/parseutil v0.1.7 h1:UpiO20jno/eV1eVZcxqWnUohyKRe1g8FPV/xH1s/2qs= @@ -76,6 +82,7 @@ github.com/mitchellh/go-wordwrap v1.0.0/go.mod h1:ZXFpozHsX6DPmq2I0TCekCxypsnAUb github.com/mitchellh/mapstructure v1.4.1/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= github.com/mitchellh/mapstructure v1.5.0 h1:jeMsZIYE/09sWLaz43PL7Gy6RuMjD2eJVyuac5Z2hdY= github.com/mitchellh/mapstructure v1.5.0/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= +github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= github.com/opentracing/opentracing-go v1.2.0 h1:uEJPy/1a5RIPAJ0Ov+OIO8OxWu77jEv+1B0VhjKrZUs= github.com/opentracing/opentracing-go v1.2.0/go.mod h1:GxEUsuufX4nBwe+T+Wl9TAgYrxe9dPLANfrWvHYVTgc= github.com/outcaste-io/ristretto v0.2.3 h1:AK4zt/fJ76kjlYObOeNwh4T3asEuaCmp26pOvUOL9w0= @@ -137,6 +144,7 @@ golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91 golang.org/x/mod v0.7.0/go.mod h1:iBbtSCu2XBx23ZKBPSOrRkjjQPZFPuis4dIYUhu/chs= golang.org/x/mod v0.14.0 h1:dGoOF9QVLYng8IHTm7BAyWqCqSheQ5pYWGhzW00YJr0= golang.org/x/mod v0.14.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= +golang.org/x/mod v0.20.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= golang.org/x/net v0.0.0-20210226172049-e18ecbb05110/go.mod h1:m0MpNAwzfU5UDzcl9v0D8zg8gWTRqZa9RBIspLL5mdg= @@ -149,6 +157,7 @@ golang.org/x/sync v0.0.0-20220722155255-886fb9371eb4/go.mod h1:RxMgew5VJxzue5/jJ golang.org/x/sync v0.1.0/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.5.0 h1:60k92dhOjHxJkrqnwsfl8KuaHbn/5dl0lUPUklKo3qE= golang.org/x/sync v0.5.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= +golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20180823144017-11551d06cbcc/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= @@ -164,6 +173,7 @@ golang.org/x/sys v0.0.0-20220722155257-8c9f86f7a55f/go.mod h1:oPkhp1MJrh7nUepCBc golang.org/x/sys v0.3.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.20.0 h1:Od9JTbYCk261bKm4M/mw7AklTlFYIa0bIp9BgSm1S8Y= golang.org/x/sys v0.20.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.23.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210927222741-03fcf44c2211/go.mod h1:jbD1KX2456YbFQfuXm/mYQcufACuNUgVhRMnK/tPxf8= golang.org/x/term v0.3.0/go.mod h1:q750SLmJuPmVoN1blW3UFBPREJfb1KmY3vwxfr+nFDA= @@ -173,6 +183,7 @@ golang.org/x/text v0.3.7/go.mod h1:u+2+/6zg+i71rQMx5EYifcz6MCKuco9NR6JIITiCfzQ= golang.org/x/text v0.5.0/go.mod h1:mrYo+phRRbMaCq/xk9113O4dZlRixOauAjOtrjsXDZ8= golang.org/x/time v0.3.0 h1:rg5rLMjNzMS1RkNLzCG38eapWhnYLFYXDXj2gOlr8j4= golang.org/x/time v0.3.0/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= +golang.org/x/time v0.6.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20191119224855-298f0cb1881e/go.mod h1:b+2E5dAYhXwXZwtnZ6UAqBI28+e2cm9otk0dWdXHAEo= golang.org/x/tools v0.1.1/go.mod h1:o0xws9oXOQQZyjljx8fwUC0k7L1pTE6eaCbjGeHmOkk= @@ -180,6 +191,7 @@ golang.org/x/tools v0.1.12/go.mod h1:hNGJHUnrk76NpqgfD5Aqm5Crs+Hm0VOH/i9J2+nxYbc golang.org/x/tools v0.4.0/go.mod h1:UE5sM2OK9E/d67R0ANs2xJizIymRP5gJU295PvKXxjQ= golang.org/x/tools v0.16.1 h1:TLyB3WofjdOEepBHAU20JdNC1Zbg87elYofWYAY5oZA= golang.org/x/tools v0.16.1/go.mod h1:kYVVN6I1mBNoB1OX+noeBjbRk4IUEPa7JJ+TJMEooJ0= +golang.org/x/tools v0.23.0/go.mod h1:pnu6ufv6vQkll6szChhK3C3L/ruaIv5eBeztNG8wtsI= golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191011141410-1b5146add898/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191204190536-9bdfabe68543/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= @@ -191,6 +203,7 @@ google.golang.org/grpc v1.57.1/go.mod h1:Sd+9RMTACXwmub0zcNY2c4arhtrbBYD1AUHI/dt google.golang.org/protobuf v1.26.0-rc.1/go.mod h1:jlhhOSvTdKEhbULTjvd4ARK9grFBp09yW+WbY/TyQbw= google.golang.org/protobuf v1.33.0 h1:uNO2rsAINq/JlFpSdYEKIZ0uKD/R9cpdv0T+yoGwGmI= google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= +google.golang.org/protobuf v1.34.2/go.mod h1:qYOHts0dSfpeUzUFpOMr/WGzszTmLH+DiWniOlNbLDw= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c h1:Hei/4ADfdWqJk1ZMxUNpqntNwaWcugrBjAiHlqqRiVk= diff --git a/internal/exectracetest/go.mod b/internal/exectracetest/go.mod index e5573375e9..a690ce9611 100644 --- a/internal/exectracetest/go.mod +++ b/internal/exectracetest/go.mod @@ -1,8 +1,6 @@ module gopkg.in/DataDog/dd-trace-go.v1/internal/exectracetest -go 1.21 - -toolchain go1.21.0 +go 1.21.0 require ( github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b @@ -13,30 +11,30 @@ require ( require ( github.com/DataDog/appsec-internal-go v1.7.0 // indirect - github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 // indirect - github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 // indirect - github.com/DataDog/datadog-go/v5 v5.3.0 // indirect + github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-go/v5 v5.5.0 // indirect github.com/DataDog/go-libddwaf/v3 v3.3.0 // indirect - github.com/DataDog/go-tuf v1.0.2-0.5.2 // indirect + github.com/DataDog/go-tuf v1.1.0-0.5.2 // indirect github.com/DataDog/sketches-go v1.4.5 // indirect github.com/Microsoft/go-winio v0.6.1 // indirect - github.com/cespare/xxhash/v2 v2.2.0 // indirect + github.com/cespare/xxhash/v2 v2.3.0 // indirect github.com/dustin/go-humanize v1.0.1 // indirect github.com/ebitengine/purego v0.6.0-alpha.5 // indirect - github.com/google/uuid v1.5.0 // indirect + github.com/google/uuid v1.6.0 // indirect github.com/outcaste-io/ristretto v0.2.3 // indirect github.com/philhofer/fwd v1.1.2 // indirect github.com/pkg/errors v0.9.1 // indirect github.com/secure-systems-lab/go-securesystemslib v0.7.0 // indirect github.com/tinylib/msgp v1.1.8 // indirect go.uber.org/atomic v1.11.0 // indirect - golang.org/x/mod v0.17.0 // indirect - golang.org/x/sync v0.7.0 // indirect - golang.org/x/sys v0.20.0 // indirect - golang.org/x/time v0.3.0 // indirect - golang.org/x/tools v0.21.0 // indirect + golang.org/x/mod v0.20.0 // indirect + golang.org/x/sync v0.8.0 // indirect + golang.org/x/sys v0.23.0 // indirect + golang.org/x/time v0.6.0 // indirect + golang.org/x/tools v0.23.0 // indirect golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 // indirect - google.golang.org/protobuf v1.33.0 // indirect + google.golang.org/protobuf v1.34.2 // indirect ) // use local version of dd-trace-go diff --git a/internal/exectracetest/go.sum b/internal/exectracetest/go.sum index 1f817550c2..1802647eda 100644 --- a/internal/exectracetest/go.sum +++ b/internal/exectracetest/go.sum @@ -2,14 +2,18 @@ github.com/DataDog/appsec-internal-go v1.7.0 h1:iKRNLih83dJeVya3IoUfK+6HLD/hQsIb github.com/DataDog/appsec-internal-go v1.7.0/go.mod h1:wW0cRfWBo4C044jHGwYiyh5moQV2x0AhnwqMuiX7O/g= github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 h1:bUMSNsw1iofWiju9yc1f+kBd33E3hMJtq9GuU602Iy8= github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0/go.mod h1:HzySONXnAgSmIQfL6gOv9hWprKJkx8CicuXuUbmgWfo= +github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1/go.mod h1:T+qq8YiHRRIuB9A1W1k9KE4Owr9anljl12Ztm7Nx8XU= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 h1:5nE6N3JSs2IG3xzMthNFhXfOaXlrsdgqmJ73lndFf8c= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1/go.mod h1:Vc+snp0Bey4MrrJyiV2tVxxJb6BmLomPvN1RgAvjGaQ= +github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= github.com/DataDog/datadog-go/v5 v5.3.0 h1:2q2qjFOb3RwAZNU+ez27ZVDwErJv5/VpbBPprz7Z+s8= github.com/DataDog/datadog-go/v5 v5.3.0/go.mod h1:XRDJk1pTc00gm+ZDiBKsjh7oOOtJfYfglVCmFb8C2+Q= +github.com/DataDog/datadog-go/v5 v5.5.0/go.mod h1:K9kcYBlxkcPP8tvvjZZKs/m1edNAUFzBbdpTUKfCsuw= github.com/DataDog/go-libddwaf/v3 v3.3.0 h1:jS72fuQpFgJZEdEJDmHJCPAgNTEMZoz1EUvimPUOiJ4= github.com/DataDog/go-libddwaf/v3 v3.3.0/go.mod h1:Bz/0JkpGf689mzbUjKJeheJINqsyyhM8p9PDuHdK2Ec= github.com/DataDog/go-tuf v1.0.2-0.5.2 h1:EeZr937eKAWPxJ26IykAdWA4A0jQXJgkhUjqEI/w7+I= github.com/DataDog/go-tuf v1.0.2-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= +github.com/DataDog/go-tuf v1.1.0-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= github.com/DataDog/gostackparse v0.7.0 h1:i7dLkXHvYzHV308hnkvVGDL3BR4FWl7IsXNPz/IGQh4= github.com/DataDog/gostackparse v0.7.0/go.mod h1:lTfqcJKqS9KnXQGnyQMCugq3u1FP6UZMfWR0aitKFMM= github.com/DataDog/sketches-go v1.4.5 h1:ki7VfeNz7IcNafq7yI/j5U/YCkO3LJiMDtXz9OMQbyE= @@ -20,6 +24,7 @@ github.com/Microsoft/go-winio v0.6.1/go.mod h1:LRdKpFKfdobln8UmuiYcKPot9D2v6svN5 github.com/cespare/xxhash/v2 v2.1.1/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= github.com/cespare/xxhash/v2 v2.2.0 h1:DC2CZ1Ep5Y4k3ZQ899DldepgrayRUGE6BBZ/cd9Cj44= github.com/cespare/xxhash/v2 v2.2.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= +github.com/cespare/xxhash/v2 v2.3.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= github.com/davecgh/go-spew v1.1.0/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.1/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc h1:U9qPSI2PIWSS1VwoXQT9A3Wy9MM3WgvqSxFWenqJduM= @@ -51,6 +56,7 @@ github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b h1:h9U78+dx9a4BKdQkBB github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b/go.mod h1:czg5+yv1E0ZGTi6S6vVK1mke0fV+FaUhNGcd6VRS9Ik= github.com/google/uuid v1.5.0 h1:1p67kYwdtXjb0gL0BPiP1Av9wiZPo5A8z2cWkTZ+eyU= github.com/google/uuid v1.5.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= +github.com/google/uuid v1.6.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/hashicorp/go-secure-stdlib/parseutil v0.1.7 h1:UpiO20jno/eV1eVZcxqWnUohyKRe1g8FPV/xH1s/2qs= github.com/hashicorp/go-secure-stdlib/parseutil v0.1.7/go.mod h1:QmrqtbKuxxSWTN3ETMPuB+VtEiBJ/A9XhoYGv8E1uD8= github.com/hashicorp/go-secure-stdlib/strutil v0.1.2 h1:kes8mmyCpxJsI7FTwtzRqEy9CdjCtrXrXGuOpxEA7Ts= @@ -125,6 +131,7 @@ golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91 golang.org/x/mod v0.7.0/go.mod h1:iBbtSCu2XBx23ZKBPSOrRkjjQPZFPuis4dIYUhu/chs= golang.org/x/mod v0.17.0 h1:zY54UmvipHiNd+pm+m0x9KhZ9hl1/7QNMyxXbc6ICqA= golang.org/x/mod v0.17.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= +golang.org/x/mod v0.20.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= golang.org/x/net v0.0.0-20210226172049-e18ecbb05110/go.mod h1:m0MpNAwzfU5UDzcl9v0D8zg8gWTRqZa9RBIspLL5mdg= @@ -137,6 +144,7 @@ golang.org/x/sync v0.0.0-20220722155255-886fb9371eb4/go.mod h1:RxMgew5VJxzue5/jJ golang.org/x/sync v0.1.0/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.7.0 h1:YsImfSBoP9QPYL0xyKJPq0gcaJdG3rInoqxTWbfQu9M= golang.org/x/sync v0.7.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= +golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20191026070338-33540a1f6037/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= @@ -151,6 +159,7 @@ golang.org/x/sys v0.0.0-20220722155257-8c9f86f7a55f/go.mod h1:oPkhp1MJrh7nUepCBc golang.org/x/sys v0.3.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.20.0 h1:Od9JTbYCk261bKm4M/mw7AklTlFYIa0bIp9BgSm1S8Y= golang.org/x/sys v0.20.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.23.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210927222741-03fcf44c2211/go.mod h1:jbD1KX2456YbFQfuXm/mYQcufACuNUgVhRMnK/tPxf8= golang.org/x/term v0.3.0/go.mod h1:q750SLmJuPmVoN1blW3UFBPREJfb1KmY3vwxfr+nFDA= @@ -160,6 +169,7 @@ golang.org/x/text v0.3.7/go.mod h1:u+2+/6zg+i71rQMx5EYifcz6MCKuco9NR6JIITiCfzQ= golang.org/x/text v0.5.0/go.mod h1:mrYo+phRRbMaCq/xk9113O4dZlRixOauAjOtrjsXDZ8= golang.org/x/time v0.3.0 h1:rg5rLMjNzMS1RkNLzCG38eapWhnYLFYXDXj2gOlr8j4= golang.org/x/time v0.3.0/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= +golang.org/x/time v0.6.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20191119224855-298f0cb1881e/go.mod h1:b+2E5dAYhXwXZwtnZ6UAqBI28+e2cm9otk0dWdXHAEo= golang.org/x/tools v0.1.1/go.mod h1:o0xws9oXOQQZyjljx8fwUC0k7L1pTE6eaCbjGeHmOkk= @@ -167,6 +177,7 @@ golang.org/x/tools v0.1.12/go.mod h1:hNGJHUnrk76NpqgfD5Aqm5Crs+Hm0VOH/i9J2+nxYbc golang.org/x/tools v0.4.0/go.mod h1:UE5sM2OK9E/d67R0ANs2xJizIymRP5gJU295PvKXxjQ= golang.org/x/tools v0.21.0 h1:qc0xYgIbsSDt9EyWz05J5wfa7LOVW0YTLOXrqdLAWIw= golang.org/x/tools v0.21.0/go.mod h1:aiJjzUbINMkxbQROHiO6hDPo2LHcIPhhQsa9DLh0yGk= +golang.org/x/tools v0.23.0/go.mod h1:pnu6ufv6vQkll6szChhK3C3L/ruaIv5eBeztNG8wtsI= golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191011141410-1b5146add898/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20200804184101-5ec99f83aff1/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= @@ -174,6 +185,7 @@ golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 h1:+cNy6SZtPcJQH3LJVLOSm golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028/go.mod h1:NDW/Ps6MPRej6fsCIbMTohpP40sJ/P/vI1MoTEGwX90= google.golang.org/protobuf v1.33.0 h1:uNO2rsAINq/JlFpSdYEKIZ0uKD/R9cpdv0T+yoGwGmI= google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= +google.golang.org/protobuf v1.34.2/go.mod h1:qYOHts0dSfpeUzUFpOMr/WGzszTmLH+DiWniOlNbLDw= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c h1:Hei/4ADfdWqJk1ZMxUNpqntNwaWcugrBjAiHlqqRiVk= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c/go.mod h1:JHkPIbrfpd72SG/EVd6muEfDQjcINNoR0C8j2r3qZ4Q= From 63bf1de1745962b35dbd0c992611b23b1b5975de Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 14 Aug 2024 10:34:22 -0400 Subject: [PATCH 02/19] Add fallback env for stats to avoid panic --- ddtrace/tracer/stats.go | 7 +++++++ 1 file changed, 7 insertions(+) diff --git a/ddtrace/tracer/stats.go b/ddtrace/tracer/stats.go index 7a745f5a3f..259acbd3c9 100644 --- a/ddtrace/tracer/stats.go +++ b/ddtrace/tracer/stats.go @@ -58,6 +58,13 @@ func newConcentrator(c *config, bucketSize int64) *concentrator { if c.env != "" { env = c.env } + if env == "" { + // We do this to avoid a panic in the stats calculation logic when env is empty + // This should never actually happen as the agent MUST have an env configured to start-up + // That panic will be removed in a future release at which point we can remove this + env = "unknown-env" + log.Error("No DD Env found, normally the agent MUST have one") + } aggKey := stats.PayloadAggregationKey{ Hostname: c.hostname, Env: env, From cd728594068879500720e05b12f28255f93164f6 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 14 Aug 2024 10:57:08 -0400 Subject: [PATCH 03/19] go mod tidy --- internal/apps/go.mod | 37 ++++++- internal/apps/go.sum | 187 ++++++++++++++++++++++++++-------- internal/exectracetest/go.mod | 35 +++++++ internal/exectracetest/go.sum | 178 ++++++++++++++++++++++++++------ 4 files changed, 362 insertions(+), 75 deletions(-) diff --git a/internal/apps/go.mod b/internal/apps/go.mod index 456c32649a..77792fee43 100644 --- a/internal/apps/go.mod +++ b/internal/apps/go.mod @@ -9,22 +9,55 @@ require ( require ( github.com/DataDog/appsec-internal-go v1.7.0 // indirect + github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 // indirect github.com/DataDog/go-libddwaf/v3 v3.3.0 // indirect + github.com/DataDog/go-sqllexer v0.0.13 // indirect + github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0 // indirect + github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575 // indirect github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc // indirect github.com/eapache/queue/v2 v2.0.0-20230407133247-75960ed334e4 // indirect github.com/ebitengine/purego v0.6.0-alpha.5 // indirect + github.com/go-ole/go-ole v1.2.6 // indirect + github.com/gogo/protobuf v1.3.2 // indirect + github.com/golang/protobuf v1.5.4 // indirect github.com/hashicorp/go-secure-stdlib/parseutil v0.1.7 // indirect github.com/hashicorp/go-secure-stdlib/strutil v0.1.2 // indirect github.com/hashicorp/go-sockaddr v1.0.2 // indirect - github.com/kr/pretty v0.3.0 // indirect + github.com/json-iterator/go v1.1.12 // indirect + github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c // indirect github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c // indirect + github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd // indirect + github.com/modern-go/reflect2 v1.0.2 // indirect github.com/outcaste-io/ristretto v0.2.3 // indirect github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2 // indirect - github.com/rogpeppe/go-internal v1.8.1 // indirect + github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c // indirect github.com/ryanuber/go-glob v1.0.0 // indirect + github.com/shirou/gopsutil/v3 v3.24.4 // indirect + github.com/shoenig/go-m1cpu v0.1.6 // indirect + github.com/tklauser/go-sysconf v0.3.12 // indirect + github.com/tklauser/numcpus v0.6.1 // indirect + github.com/yusufpapurcu/wmi v1.2.4 // indirect + go.opentelemetry.io/collector/component v0.104.0 // indirect + go.opentelemetry.io/collector/config/configtelemetry v0.104.0 // indirect + go.opentelemetry.io/collector/pdata v1.11.0 // indirect + go.opentelemetry.io/collector/semconv v0.104.0 // indirect + go.opentelemetry.io/otel v1.27.0 // indirect + go.opentelemetry.io/otel/metric v1.27.0 // indirect + go.opentelemetry.io/otel/trace v1.27.0 // indirect go.uber.org/atomic v1.11.0 // indirect + go.uber.org/multierr v1.11.0 // indirect + go.uber.org/zap v1.27.0 // indirect golang.org/x/mod v0.20.0 // indirect + golang.org/x/net v0.27.0 // indirect + golang.org/x/text v0.16.0 // indirect golang.org/x/tools v0.23.0 // indirect + google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 // indirect + google.golang.org/grpc v1.64.0 // indirect + gopkg.in/ini.v1 v1.67.0 // indirect + gopkg.in/yaml.v2 v2.4.0 // indirect gopkg.in/yaml.v3 v3.0.1 // indirect ) diff --git a/internal/apps/go.sum b/internal/apps/go.sum index a7dd534716..4297013c28 100644 --- a/internal/apps/go.sum +++ b/internal/apps/go.sum @@ -1,39 +1,50 @@ github.com/DataDog/appsec-internal-go v1.7.0 h1:iKRNLih83dJeVya3IoUfK+6HLD/hQsIbyBlfvLmAeb0= github.com/DataDog/appsec-internal-go v1.7.0/go.mod h1:wW0cRfWBo4C044jHGwYiyh5moQV2x0AhnwqMuiX7O/g= -github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 h1:bUMSNsw1iofWiju9yc1f+kBd33E3hMJtq9GuU602Iy8= -github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0/go.mod h1:HzySONXnAgSmIQfL6gOv9hWprKJkx8CicuXuUbmgWfo= +github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 h1:18/yZ0yKjCnTPkBW7K8LdRiRiVaYjKF0yE1QHfMA7yI= github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1/go.mod h1:T+qq8YiHRRIuB9A1W1k9KE4Owr9anljl12Ztm7Nx8XU= -github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 h1:5nE6N3JSs2IG3xzMthNFhXfOaXlrsdgqmJ73lndFf8c= -github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1/go.mod h1:Vc+snp0Bey4MrrJyiV2tVxxJb6BmLomPvN1RgAvjGaQ= +github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 h1:qq3MUh7MdkywBpjm0HRaYOfcunNemWI+wO4u2w1GWnA= +github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1/go.mod h1:5h7i2YkGEM4QOu4TUaYeSPZ1BeuXaseA276cCrSvCmM= +github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 h1:hVa76HpVox8Xt05qpLuqAngd9+1waSA5IVQqCFJ2RPQ= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= -github.com/DataDog/datadog-go/v5 v5.3.0 h1:2q2qjFOb3RwAZNU+ez27ZVDwErJv5/VpbBPprz7Z+s8= -github.com/DataDog/datadog-go/v5 v5.3.0/go.mod h1:XRDJk1pTc00gm+ZDiBKsjh7oOOtJfYfglVCmFb8C2+Q= +github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 h1:iMJU0lqQvrpJ6LCLTWwbUlCWaazurhwwvWf8FKsaOs4= +github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1/go.mod h1:RdepkDr3A0tJ6G/B4MfMy1fzEYHovykN7pnXOK1vePg= +github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 h1:Bx5kkulMNaTgNH8/Piu0wpwOhd4BZR7Ht0SMv4zAKQg= +github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1/go.mod h1:S/D5aNZadFQk6IWKghTnuiKVyD+9OfSfsm116VY+xlU= +github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 h1:7IY8ST69RNo+x7Z2Y99BtsLPqFyTZWTh9LWWFYQBr3A= +github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1/go.mod h1:8ASCNWHQtcmUedxL+WjbCPSIcGIM8LeVzil7JCzx0js= +github.com/DataDog/datadog-go/v5 v5.5.0 h1:G5KHeB8pWBNXT4Jtw0zAkhdxEAWSpWH00geHI6LDrKU= github.com/DataDog/datadog-go/v5 v5.5.0/go.mod h1:K9kcYBlxkcPP8tvvjZZKs/m1edNAUFzBbdpTUKfCsuw= github.com/DataDog/go-libddwaf/v3 v3.3.0 h1:jS72fuQpFgJZEdEJDmHJCPAgNTEMZoz1EUvimPUOiJ4= github.com/DataDog/go-libddwaf/v3 v3.3.0/go.mod h1:Bz/0JkpGf689mzbUjKJeheJINqsyyhM8p9PDuHdK2Ec= -github.com/DataDog/go-tuf v1.0.2-0.5.2 h1:EeZr937eKAWPxJ26IykAdWA4A0jQXJgkhUjqEI/w7+I= -github.com/DataDog/go-tuf v1.0.2-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= +github.com/DataDog/go-sqllexer v0.0.13 h1:9mKfe+3s73GI/7dWBxi2Ds7+xZynJqMKK9cIUBrutak= +github.com/DataDog/go-sqllexer v0.0.13/go.mod h1:KwkYhpFEVIq+BfobkTC1vfqm4gTi65skV/DpDBXtexc= +github.com/DataDog/go-tuf v1.1.0-0.5.2 h1:4CagiIekonLSfL8GMHRHcHudo1fQnxELS9g4tiAupQ4= github.com/DataDog/go-tuf v1.1.0-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= github.com/DataDog/gostackparse v0.7.0 h1:i7dLkXHvYzHV308hnkvVGDL3BR4FWl7IsXNPz/IGQh4= github.com/DataDog/gostackparse v0.7.0/go.mod h1:lTfqcJKqS9KnXQGnyQMCugq3u1FP6UZMfWR0aitKFMM= +github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0 h1:10TPqpTlIkmDPFWVIEZ4ZX3rWrCrx3rEoeoAooZr6LM= +github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0/go.mod h1:dvIWN9pA2zWNTw5rhDWZgzZnhcfpH++d+8d1SWW6xkY= github.com/DataDog/sketches-go v1.4.5 h1:ki7VfeNz7IcNafq7yI/j5U/YCkO3LJiMDtXz9OMQbyE= github.com/DataDog/sketches-go v1.4.5/go.mod h1:7Y8GN8Jf66DLyDhc94zuWA3uHEt/7ttt8jHOBWWrSOg= github.com/Microsoft/go-winio v0.5.0/go.mod h1:JPGBdM1cNvN/6ISo+n8V5iA4v8pBzdOpzfwIujj1a84= github.com/Microsoft/go-winio v0.6.1 h1:9/kr64B9VUZrLm5YYwbGtUJnMgqWVOdUAXu6Migciow= github.com/Microsoft/go-winio v0.6.1/go.mod h1:LRdKpFKfdobln8UmuiYcKPot9D2v6svN5+sAH+4kjUM= github.com/armon/go-radix v0.0.0-20180808171621-7fddfc383310/go.mod h1:ufUuZ+zHj4x4TnLV4JWEpy2hxWSpsRywHrMgIH9cCH8= +github.com/beorn7/perks v1.0.1 h1:VlbKKnNfV8bJzeqoa4cOKqO6bYr3WgKZxO8Z16+hsOM= +github.com/beorn7/perks v1.0.1/go.mod h1:G2ZrVWU2WbWT9wwq4/hrbKbnv/1ERSJQ0ibhJ6rlkpw= github.com/bgentry/speakeasy v0.1.0/go.mod h1:+zsyZBPWlz7T6j88CTgSN5bM796AkVf0kBD4zp0CCIs= github.com/cespare/xxhash/v2 v2.1.1/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= -github.com/cespare/xxhash/v2 v2.2.0 h1:DC2CZ1Ep5Y4k3ZQ899DldepgrayRUGE6BBZ/cd9Cj44= -github.com/cespare/xxhash/v2 v2.2.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= +github.com/cespare/xxhash/v2 v2.3.0 h1:UL815xU9SqsFlibzuggzjXhog7bL6oX9BbNZnL2UFvs= github.com/cespare/xxhash/v2 v2.3.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= -github.com/creack/pty v1.1.9/go.mod h1:oKZEueFk5CKHvIhNR5MUki03XCEU+Q6VDXinZuGJ33E= +github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575 h1:kHaBemcxl8o/pQ5VM1c8PVE1PubbNx3mjUr09OqWGCs= +github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575/go.mod h1:9d6lWj8KzO/fd/NrVaLscBKmPigpZpn5YawRPw+e3Yo= github.com/davecgh/go-spew v1.1.0/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.1/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc h1:U9qPSI2PIWSS1VwoXQT9A3Wy9MM3WgvqSxFWenqJduM= github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= -github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2 h1:tdlZCpZ/P9DhczCTSixgIKmwPv6+wP5DGjqLYw5SUiA= github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2/go.mod h1:SqUrOPUnsFjfmXRMNPybcSiG0BgUW2AuFH8PAnS2iTw= +github.com/dgryski/go-farm v0.0.0-20200201041132-a6ae2369ad13 h1:fAjc9m62+UWV/WAFKLNi6ZS0675eEUC9y3AlwSbQu1Y= +github.com/dgryski/go-farm v0.0.0-20200201041132-a6ae2369ad13/go.mod h1:SqUrOPUnsFjfmXRMNPybcSiG0BgUW2AuFH8PAnS2iTw= github.com/dustin/go-humanize v1.0.0/go.mod h1:HtrtbFcZ19U5GC7JDqmcUSB87Iq5E25KnS6fMYU6eOk= github.com/dustin/go-humanize v1.0.1 h1:GzkhY7T5VNhEkwH0PVJgjz+fX1rhBrR7pRT3mDkpeCY= github.com/dustin/go-humanize v1.0.1/go.mod h1:Mu1zIs6XwVuF/gI1OepvI0qD18qycQx+mFykh5fBlto= @@ -44,18 +55,30 @@ github.com/ebitengine/purego v0.6.0-alpha.5/go.mod h1:ah1In8AOtksoNK6yk5z1HTJeUk github.com/fatih/color v1.7.0/go.mod h1:Zm6kSWBoL9eyXnKyktHP6abPY2pDugNf5KwzbycvMj4= github.com/glebarez/go-sqlite v1.22.0 h1:uAcMJhaA6r3LHMTFgP0SifzgXg46yJkgxqyuyec+ruQ= github.com/glebarez/go-sqlite v1.22.0/go.mod h1:PlBIdHe0+aUEFn+r2/uthrWq4FxbzugL0L8Li6yQJbc= +github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= +github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= +github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= +github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= +github.com/go-ole/go-ole v1.2.6 h1:/Fpf6oFPoeFik9ty7siob0G6Ke8QvQEuVcuChpwXzpY= +github.com/go-ole/go-ole v1.2.6/go.mod h1:pprOEPIfldk/42T2oK7lQ4v4JSDwmV0As9GaiUsvbm0= +github.com/gogo/protobuf v1.3.2 h1:Ov1cvc58UF3b5XjBnZv7+opcTcQFZebYjWzi34vdm4Q= +github.com/gogo/protobuf v1.3.2/go.mod h1:P1XiOD3dCwIKUDQYPy72D8LYyHL2YPYrpS2s69NZV8Q= github.com/golang/mock v1.6.0/go.mod h1:p6yTPP+5HYm5mzsMV8JkE6ZKdX+/wYM6Hr+LicevLPs= github.com/golang/protobuf v1.5.0/go.mod h1:FsONVRAS9T7sI+LIUmWTfcYkHO4aIWwzhcaSAoJOfIk= +github.com/golang/protobuf v1.5.4 h1:i7eJL8qZTpSEXOPTxNKhASYpMn+8e5Q6AdndVa1dWek= +github.com/golang/protobuf v1.5.4/go.mod h1:lnTiLA8Wa4RWRcIUkrtSVa5nRhsEGBg48fD6rSs7xps= github.com/google/go-cmp v0.5.5/go.mod h1:v8dTdLbMG2kIc/vJvl+f65V22dbkXbowE6jgT/gNBxE= +github.com/google/go-cmp v0.5.6/go.mod h1:v8dTdLbMG2kIc/vJvl+f65V22dbkXbowE6jgT/gNBxE= +github.com/google/go-cmp v0.5.9/go.mod h1:17dUlkBOakJ0+DkrSSNjCkIjxS6bF9zb3elmeNGIjoY= github.com/google/go-cmp v0.6.0 h1:ofyhxvXcZhMsU5ulbFiLKl/XBFqE1GSq7atu8tAmTRI= github.com/google/go-cmp v0.6.0/go.mod h1:17dUlkBOakJ0+DkrSSNjCkIjxS6bF9zb3elmeNGIjoY= +github.com/google/gofuzz v1.0.0/go.mod h1:dBl0BpW6vV/+mYPU4Po3pmUjxk6FQPldtuIdl/M65Eg= github.com/google/gofuzz v1.1.0/go.mod h1:dBl0BpW6vV/+mYPU4Po3pmUjxk6FQPldtuIdl/M65Eg= github.com/google/gofuzz v1.2.0 h1:xRy4A+RhZaiKjJ1bPfwQ8sedCA+YS2YcCHW6ec7JMi0= github.com/google/gofuzz v1.2.0/go.mod h1:dBl0BpW6vV/+mYPU4Po3pmUjxk6FQPldtuIdl/M65Eg= github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b h1:h9U78+dx9a4BKdQkBBos92HalKpaGKHrp+3Uo6yTodo= github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b/go.mod h1:czg5+yv1E0ZGTi6S6vVK1mke0fV+FaUhNGcd6VRS9Ik= -github.com/google/uuid v1.5.0 h1:1p67kYwdtXjb0gL0BPiP1Av9wiZPo5A8z2cWkTZ+eyU= -github.com/google/uuid v1.5.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= +github.com/google/uuid v1.6.0 h1:NIvaJDMOsjHA8n1jAhLSgzrAzy1Hgr+hNrb57e+94F0= github.com/google/uuid v1.6.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/hashicorp/errwrap v1.0.0/go.mod h1:YH+1FKiLXxHSkmPseP+kNlulaMuP3n2brvKWEqk/Jc4= github.com/hashicorp/go-multierror v1.0.0/go.mod h1:dHtQlpGsu+cZNNAkkCN/P3hoUDHhCYQXV3UM06sGGrk= @@ -66,13 +89,17 @@ github.com/hashicorp/go-secure-stdlib/strutil v0.1.2 h1:kes8mmyCpxJsI7FTwtzRqEy9 github.com/hashicorp/go-secure-stdlib/strutil v0.1.2/go.mod h1:Gou2R9+il93BqX25LAKCLuM+y9U2T4hlwvT1yprcna4= github.com/hashicorp/go-sockaddr v1.0.2 h1:ztczhD1jLxIRjVejw8gFomI1BQZOe2WoVOu0SyteCQc= github.com/hashicorp/go-sockaddr v1.0.2/go.mod h1:rB4wwRAUzs07qva3c5SdrY/NEtAUjGlgmH/UkBUC97A= -github.com/kr/pretty v0.1.0/go.mod h1:dAy3ld7l9f0ibDNOQOHHMYYIIbhfbHSm3C4ZsoJORNo= -github.com/kr/pretty v0.3.0 h1:WgNl7dwNpEZ6jJ9k1snq4pZsg7DOEN8hP9Xw0Tsjwk0= -github.com/kr/pretty v0.3.0/go.mod h1:640gp4NfQd8pI5XOwp5fnNeVWj67G7CFk/SaSQn7NBk= -github.com/kr/pty v1.1.1/go.mod h1:pFQYn66WHrOpPYNljwOMqo10TkYh1fy3cYio2l3bCsQ= -github.com/kr/text v0.1.0/go.mod h1:4Jbv+DJW3UT/LiOwJeYQe1efqtUx/iVham/4vfdArNI= +github.com/json-iterator/go v1.1.12 h1:PV8peI4a0ysnczrg+LtxykD8LfKY9ML6u2jnxaEnrnM= +github.com/json-iterator/go v1.1.12/go.mod h1:e30LSqwooZae/UwlEbR2852Gd8hjQvJoHmT4TnhNGBo= +github.com/kisielk/errcheck v1.5.0/go.mod h1:pFxgyoBC7bSaBwPgfKdkLd5X25qrDl4LWUI2bnpBCr8= +github.com/kisielk/gotool v1.0.0/go.mod h1:XhKaO+MFFWcvkIS/tQcRk01m1F5IRFswLeQ+oQHNcck= +github.com/kr/pretty v0.3.1 h1:flRD4NNwYAUpkphVc1HcthR4KEIFJ65n8Mw5qdRn3LE= +github.com/kr/pretty v0.3.1/go.mod h1:hoEshYVHaxMs3cyo3Yncou5ZscifuDolrwPKZanG3xk= github.com/kr/text v0.2.0 h1:5Nx0Ya0ZqY2ygV366QzturHI13Jq95ApcVaJBhpS+AY= github.com/kr/text v0.2.0/go.mod h1:eLer722TekiGuMkidMxC/pM04lWEeraHUUmBw8l2grE= +github.com/lufia/plan9stats v0.0.0-20211012122336-39d0f177ccd0/go.mod h1:zJYVVT2jmtg6P3p1VtQj7WsuWi/y4VnjVBn7F8KPB3I= +github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c h1:VtwQ41oftZwlMnOEbMWQtSEUgU64U4s+GHk7hZK+jtY= +github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c/go.mod h1:JKx41uQRwqlTZabZc+kILPrO/3jlKnQ2Z8b7YiVw5cE= github.com/mattn/go-colorable v0.0.9/go.mod h1:9vuHe8Xs5qXnSaW/c/ABM9alt+Vo+STaOChaDxuIBZU= github.com/mattn/go-isatty v0.0.3/go.mod h1:M+lRXTBqGeGNdLjl/ufCoiOlB5xdOkqRJdNxMWT7Zi4= github.com/mattn/go-isatty v0.0.20 h1:xfD0iDuEKnDkl03q4limB+vH+GxLEtL/jb4xVJSWWEY= @@ -80,34 +107,53 @@ github.com/mattn/go-isatty v0.0.20/go.mod h1:W+V8PltTTMOvKvAeJH7IuucS94S2C6jfK/D github.com/mitchellh/cli v1.0.0/go.mod h1:hNIlj7HEI86fIcpObd7a0FcrxTWetlwJDGcceTlRvqc= github.com/mitchellh/go-wordwrap v1.0.0/go.mod h1:ZXFpozHsX6DPmq2I0TCekCxypsnAUbP2oI0UX1GXzOo= github.com/mitchellh/mapstructure v1.4.1/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= -github.com/mitchellh/mapstructure v1.5.0 h1:jeMsZIYE/09sWLaz43PL7Gy6RuMjD2eJVyuac5Z2hdY= -github.com/mitchellh/mapstructure v1.5.0/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= +github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c h1:cqn374mizHuIWj+OSJCajGr/phAmuMug9qIX3l9CflE= github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= +github.com/modern-go/concurrent v0.0.0-20180228061459-e0a39a4cb421/go.mod h1:6dJC0mAP4ikYIbvyc7fijjWJddQyLn8Ig3JB5CqoB9Q= +github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd h1:TRLaZ9cD/w8PVh93nsPXa1VrQ6jlwL5oN8l14QlcNfg= +github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd/go.mod h1:6dJC0mAP4ikYIbvyc7fijjWJddQyLn8Ig3JB5CqoB9Q= +github.com/modern-go/reflect2 v1.0.2 h1:xBagoLtFs94CBntxluKeaWgTMpvLxC4ur3nMaC9Gz0M= +github.com/modern-go/reflect2 v1.0.2/go.mod h1:yWuevngMOJpCy52FWWMvUC8ws7m/LJsjYzDa0/r8luk= github.com/opentracing/opentracing-go v1.2.0 h1:uEJPy/1a5RIPAJ0Ov+OIO8OxWu77jEv+1B0VhjKrZUs= github.com/opentracing/opentracing-go v1.2.0/go.mod h1:GxEUsuufX4nBwe+T+Wl9TAgYrxe9dPLANfrWvHYVTgc= github.com/outcaste-io/ristretto v0.2.3 h1:AK4zt/fJ76kjlYObOeNwh4T3asEuaCmp26pOvUOL9w0= github.com/outcaste-io/ristretto v0.2.3/go.mod h1:W8HywhmtlopSB1jeMg3JtdIhf+DYkLAr0VN/s4+MHac= github.com/philhofer/fwd v1.1.2 h1:bnDivRJ1EWPjUIRXV5KfORO897HTbpFAQddBdE8t7Gw= github.com/philhofer/fwd v1.1.2/go.mod h1:qkPdfjR2SIEbspLqpe1tO4n5yICnr2DY7mqEx2tUTP0= -github.com/pkg/diff v0.0.0-20210226163009-20ebb0f2a09e/go.mod h1:pJLUxLENpZxwdsKMEsNbx1VGcRFpLqf3715MtcvvzbA= github.com/pkg/errors v0.9.1 h1:FEBLx1zS214owpjy7qsBeixbURkuhQAwrK5UwLGTwt4= github.com/pkg/errors v0.9.1/go.mod h1:bwawxfHBFNV+L2hUp1rHADufV3IMtnDRdf1r5NINEl0= github.com/pmezard/go-difflib v1.0.0/go.mod h1:iKH77koFhYxTK1pcRnkKkqfTogsbg7gZNVY4sRDYZ/4= github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2 h1:Jamvg5psRIccs7FGNTlIRMkT8wgtp5eCXdBlqhYGL6U= github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2/go.mod h1:iKH77koFhYxTK1pcRnkKkqfTogsbg7gZNVY4sRDYZ/4= github.com/posener/complete v1.1.1/go.mod h1:em0nMJCgc9GFtwrmVmEMR/ZL6WyhyjMBndrE9hABlRI= +github.com/power-devops/perfstat v0.0.0-20210106213030-5aafc221ea8c/go.mod h1:OmDBASR4679mdNQnz2pUhc2G8CO2JrUAVFDRBDP/hJE= +github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c h1:NRoLoZvkBTKvR5gQLgA3e0hqjkY9u1wm+iOL45VN/qI= +github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c/go.mod h1:OmDBASR4679mdNQnz2pUhc2G8CO2JrUAVFDRBDP/hJE= +github.com/prometheus/client_golang v1.19.1 h1:wZWJDwK+NameRJuPGDhlnFgx8e8HN3XHQeLaYJFJBOE= +github.com/prometheus/client_golang v1.19.1/go.mod h1:mP78NwGzrVks5S2H6ab8+ZZGJLZUq1hoULYBAYBw1Ho= +github.com/prometheus/client_model v0.6.1 h1:ZKSh/rekM+n3CeS952MLRAdFwIKqeY8b62p8ais2e9E= +github.com/prometheus/client_model v0.6.1/go.mod h1:OrxVMOVHjw3lKMa8+x6HeMGkHMQyHDk9E3jmP2AmGiY= +github.com/prometheus/common v0.54.0 h1:ZlZy0BgJhTwVZUn7dLOkwCZHUkrAqd3WYtcFCWnM1D8= +github.com/prometheus/common v0.54.0/go.mod h1:/TQgMJP5CuVYveyT7n/0Ix8yLNNXy9yRSkhnLTHPDIQ= +github.com/prometheus/procfs v0.15.0 h1:A82kmvXJq2jTu5YUhSGNlYoxh85zLnKgPz4bMZgI5Ek= +github.com/prometheus/procfs v0.15.0/go.mod h1:Y0RJ/Y5g5wJpkTisOtqwDSo4HwhGmLB4VQSw2sQJLHk= github.com/remyoudompheng/bigfft v0.0.0-20230129092748-24d4a6f8daec h1:W09IVJc94icq4NjY3clb7Lk8O1qJ8BdBEF8z0ibU0rE= github.com/remyoudompheng/bigfft v0.0.0-20230129092748-24d4a6f8daec/go.mod h1:qqbHyh8v60DhA7CoWK5oRCqLrMHRGoxYCSS9EjAz6Eo= github.com/richardartoul/molecule v1.0.1-0.20240531184615-7ca0df43c0b3 h1:4+LEVOB87y175cLJC/mbsgKmoDOjrBldtXvioEy96WY= github.com/richardartoul/molecule v1.0.1-0.20240531184615-7ca0df43c0b3/go.mod h1:vl5+MqJ1nBINuSsUI2mGgH79UweUT/B5Fy8857PqyyI= -github.com/rogpeppe/go-internal v1.6.1/go.mod h1:xXDCJY+GAPziupqXw64V24skbSoqbTEfhy4qGm1nDQc= -github.com/rogpeppe/go-internal v1.8.1 h1:geMPLpDpQOgVyCg5z5GoRwLHepNdb71NXb67XFkP+Eg= -github.com/rogpeppe/go-internal v1.8.1/go.mod h1:JeRgkft04UBgHMgCIwADu4Pn6Mtm5d4nPKWu0nJ5d+o= +github.com/rogpeppe/go-internal v1.10.0 h1:TMyTOH3F/DB16zRVcYyreMH6GnZZrwQVAoYjRBZyWFQ= +github.com/rogpeppe/go-internal v1.10.0/go.mod h1:UQnix2H7Ngw/k4C5ijL5+65zddjncjaFoBhdsK/akog= github.com/ryanuber/columnize v2.1.0+incompatible/go.mod h1:sm1tb6uqfes/u+d4ooFouqFdy9/2g9QGwK3SQygK0Ts= github.com/ryanuber/go-glob v1.0.0 h1:iQh3xXAumdQ+4Ufa5b25cRpC5TYKlno6hsv6Cb3pkBk= github.com/ryanuber/go-glob v1.0.0/go.mod h1:807d1WSdnB0XRJzKNil9Om6lcp/3a0v4qIHxIXzX/Yc= github.com/secure-systems-lab/go-securesystemslib v0.7.0 h1:OwvJ5jQf9LnIAS83waAjPbcMsODrTQUpJ02eNLUoxBg= github.com/secure-systems-lab/go-securesystemslib v0.7.0/go.mod h1:/2gYnlnHVQ6xeGtfIqFy7Do03K4cdCY0A/GlJLDKLHI= +github.com/shirou/gopsutil/v3 v3.24.4 h1:dEHgzZXt4LMNm+oYELpzl9YCqV65Yr/6SfrvgRBtXeU= +github.com/shirou/gopsutil/v3 v3.24.4/go.mod h1:lTd2mdiOspcqLgAnr9/nGi71NkeMpWKdmhuxm9GusH8= +github.com/shoenig/go-m1cpu v0.1.6 h1:nxdKQNcEB6vzgA2E2bvzKIYRuNj7XNJ4S/aRSwKzFtM= +github.com/shoenig/go-m1cpu v0.1.6/go.mod h1:1JJMcUBvfNwpq05QDQVAnx3gUHr9IYF7GNg9SUEw2VQ= +github.com/shoenig/test v0.6.4 h1:kVTaSd7WLz5WZ2IaoM0RSzRsUD+m8wRR+5qvntpn4LU= +github.com/shoenig/test v0.6.4/go.mod h1:byHiCGXqrVaflBLAMq/srcZIHynQPQgeyvkvXnjqq0k= github.com/sirupsen/logrus v1.7.0/go.mod h1:yWOB1SBYBC5VeMP7gHvWumXLIWorT60ONWic61uBYv0= github.com/spaolacci/murmur3 v1.1.0 h1:7c1g84S4BPRrfL5Xrdp6fOJ206sU9y293DDHaoy0bLI= github.com/spaolacci/murmur3 v1.1.0/go.mod h1:JwIasOWyU6f++ZhiEuf87xNszmSA2myDM2Kzu9HwQUA= @@ -123,46 +169,93 @@ github.com/stretchr/testify v1.7.0/go.mod h1:6Fq8oRcR53rry900zMqJjRRixrwX3KX962/ github.com/stretchr/testify v1.7.1/go.mod h1:6Fq8oRcR53rry900zMqJjRRixrwX3KX962/h/Wwjteg= github.com/stretchr/testify v1.8.0/go.mod h1:yNjHg4UonilssWZ8iaSj1OCr/vHnekPRkoO+kdMU+MU= github.com/stretchr/testify v1.8.1/go.mod h1:w2LPCIKwWwSfY2zedu0+kehJoqGctiVI29o6fzry7u4= +github.com/stretchr/testify v1.8.4/go.mod h1:sz/lmYIOXD/1dqDmKjjqLyZ2RngseejIcXlSw2iwfAo= github.com/stretchr/testify v1.9.0 h1:HtqpIVDClZ4nwg75+f6Lvsy/wHu+3BoSGCbBAcpTsTg= github.com/stretchr/testify v1.9.0/go.mod h1:r2ic/lqez/lEtzL7wO/rwa5dbSLXVDPFyf8C91i36aY= github.com/tinylib/msgp v1.1.8 h1:FCXC1xanKO4I8plpHGH2P7koL/RzZs12l/+r7vakfm0= github.com/tinylib/msgp v1.1.8/go.mod h1:qkpG+2ldGg4xRFmx+jfTvZPxfGFhi64BcnL9vkCm/Tw= +github.com/tklauser/go-sysconf v0.3.12 h1:0QaGUFOdQaIVdPgfITYzaTegZvdCjmYO52cSFAEVmqU= +github.com/tklauser/go-sysconf v0.3.12/go.mod h1:Ho14jnntGE1fpdOqQEEaiKRpvIavV0hSfmBq8nJbHYI= +github.com/tklauser/numcpus v0.6.1 h1:ng9scYS7az0Bk4OZLvrNXNSAO2Pxr1XXRAPyjhIx+Fk= +github.com/tklauser/numcpus v0.6.1/go.mod h1:1XfjsgE2zo8GVw7POkMbHENHzVg3GzmoZ9fESEdAacY= +github.com/vmihailenco/msgpack/v4 v4.3.12 h1:07s4sz9IReOgdikxLTKNbBdqDMLsjPKXwvCazn8G65U= +github.com/vmihailenco/msgpack/v4 v4.3.12/go.mod h1:gborTTJjAo/GWTqqRjrLCn9pgNN+NXzzngzBKDPIqw4= +github.com/vmihailenco/tagparser v0.1.2 h1:gnjoVuB/kljJ5wICEEOpx98oXMWPLj22G67Vbd1qPqc= +github.com/vmihailenco/tagparser v0.1.2/go.mod h1:OeAg3pn3UbLjkWt+rN9oFYB6u/cQgqMEUPoW2WPyhdI= +github.com/yuin/goldmark v1.1.27/go.mod h1:3hX8gzYuyVAZsxl0MRgGTJEmQBFcNTphYh9decYSb74= +github.com/yuin/goldmark v1.2.1/go.mod h1:3hX8gzYuyVAZsxl0MRgGTJEmQBFcNTphYh9decYSb74= github.com/yuin/goldmark v1.3.5/go.mod h1:mwnBkeHKe2W/ZEtQ+71ViKU8L12m81fl3OWwC1Zlc8k= github.com/yuin/goldmark v1.4.13/go.mod h1:6yULJ656Px+3vBD8DxQVa3kxgyrAnzto9xy5taEt/CY= +github.com/yusufpapurcu/wmi v1.2.4 h1:zFUKzehAFReQwLys1b/iSMl+JQGSCSjtVqQn9bBrPo0= +github.com/yusufpapurcu/wmi v1.2.4/go.mod h1:SBZ9tNy3G9/m5Oi98Zks0QjeHVDvuK0qfxQmPyzfmi0= +go.opentelemetry.io/collector/component v0.104.0 h1:jqu/X9rnv8ha0RNZ1a9+x7OU49KwSMsPbOuIEykHuQE= +go.opentelemetry.io/collector/component v0.104.0/go.mod h1:1C7C0hMVSbXyY1ycCmaMUAR9fVwpgyiNQqxXtEWhVpw= +go.opentelemetry.io/collector/config/configtelemetry v0.104.0 h1:eHv98XIhapZA8MgTiipvi+FDOXoFhCYOwyKReOt+E4E= +go.opentelemetry.io/collector/config/configtelemetry v0.104.0/go.mod h1:WxWKNVAQJg/Io1nA3xLgn/DWLE/W1QOB2+/Js3ACi40= +go.opentelemetry.io/collector/pdata v1.11.0 h1:rzYyV1zfTQQz1DI9hCiaKyyaczqawN75XO9mdXmR/hE= +go.opentelemetry.io/collector/pdata v1.11.0/go.mod h1:IHxHsp+Jq/xfjORQMDJjSH6jvedOSTOyu3nbxqhWSYE= +go.opentelemetry.io/collector/semconv v0.104.0 h1:dUvajnh+AYJLEW/XOPk0T0BlwltSdi3vrjO7nSOos3k= +go.opentelemetry.io/collector/semconv v0.104.0/go.mod h1:yMVUCNoQPZVq/IPfrHrnntZTWsLf5YGZ7qwKulIl5hw= +go.opentelemetry.io/otel v1.27.0 h1:9BZoF3yMK/O1AafMiQTVu0YDj5Ea4hPhxCs7sGva+cg= +go.opentelemetry.io/otel v1.27.0/go.mod h1:DMpAK8fzYRzs+bi3rS5REupisuqTheUlSZJ1WnZaPAQ= +go.opentelemetry.io/otel/exporters/prometheus v0.49.0 h1:Er5I1g/YhfYv9Affk9nJLfH/+qCCVVg1f2R9AbJfqDQ= +go.opentelemetry.io/otel/exporters/prometheus v0.49.0/go.mod h1:KfQ1wpjf3zsHjzP149P4LyAwWRupc6c7t1ZJ9eXpKQM= +go.opentelemetry.io/otel/metric v1.27.0 h1:hvj3vdEKyeCi4YaYfNjv2NUje8FqKqUY8IlF0FxV/ik= +go.opentelemetry.io/otel/metric v1.27.0/go.mod h1:mVFgmRlhljgBiuk/MP/oKylr4hs85GZAylncepAX/ak= +go.opentelemetry.io/otel/sdk v1.27.0 h1:mlk+/Y1gLPLn84U4tI8d3GNJmGT/eXe3ZuOXN9kTWmI= +go.opentelemetry.io/otel/sdk v1.27.0/go.mod h1:Ha9vbLwJE6W86YstIywK2xFfPjbWlCuwPtMkKdz/Y4A= +go.opentelemetry.io/otel/sdk/metric v1.27.0 h1:5uGNOlpXi+Hbo/DRoI31BSb1v+OGcpv2NemcCrOL8gI= +go.opentelemetry.io/otel/sdk/metric v1.27.0/go.mod h1:we7jJVrYN2kh3mVBlswtPU22K0SA+769l93J6bsyvqw= +go.opentelemetry.io/otel/trace v1.27.0 h1:IqYb813p7cmbHk0a5y6pD5JPakbVfftRXABGt5/Rscw= +go.opentelemetry.io/otel/trace v1.27.0/go.mod h1:6RiD1hkAprV4/q+yd2ln1HG9GoPx39SuvvstaLBl+l4= go.uber.org/atomic v1.9.0/go.mod h1:fEN4uk6kAWBTFdckzkM89CLk9XfWZrxpCo0nPH17wJc= go.uber.org/atomic v1.11.0 h1:ZvwS0R+56ePWxUNi+Atn9dWONBPp/AUETXlHW0DxSjE= go.uber.org/atomic v1.11.0/go.mod h1:LUxbIzbOniOlMKjJjyPfpl4v+PKK2cNJn91OQbhoJI0= go.uber.org/goleak v1.3.0 h1:2K3zAYmnTNqV73imy9J1T3WC+gmCePx2hEGkimedGto= go.uber.org/goleak v1.3.0/go.mod h1:CoHD4mav9JJNrW/WLlf7HGZPjdw8EucARQHekz1X6bE= +go.uber.org/multierr v1.11.0 h1:blXXJkSxSSfBVBlC76pxqeO+LN3aDfLQo+309xJstO0= +go.uber.org/multierr v1.11.0/go.mod h1:20+QtiLqy0Nd6FdQB9TLXag12DsQkrbs3htMFfDN80Y= +go.uber.org/zap v1.27.0 h1:aJMhYGrd5QSmlpLMr2MftRKl7t8J8PTZPA732ud/XR8= +go.uber.org/zap v1.27.0/go.mod h1:GB2qFLM7cTU87MWRP2mPIjqfIDnGu+VIO4V/SdhGo2E= golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACkg1iLfiJU5Ep61QUkGW8qpdssI0+w= golang.org/x/crypto v0.0.0-20191011191535-87dc89f01550/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= +golang.org/x/crypto v0.0.0-20200622213623-75b288015ac9/go.mod h1:LzIPMQfyMNhhGPhUkYOs5KpL4U8rLKemX1yGLhDgUto= golang.org/x/crypto v0.0.0-20210921155107-089bfa567519/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= -golang.org/x/crypto v0.21.0 h1:X31++rzVUdKhX5sWmSOFZxx8UW/ldWx55cbf08iNAMA= -golang.org/x/crypto v0.21.0/go.mod h1:0BP7YvVV9gBbVKyeTG0Gyn+gZm94bibOW5BjDEYAOMs= +golang.org/x/crypto v0.25.0 h1:ypSNr+bnYL2YhwoMt2zPxHFmbAN1KZs/njMG3hxUp30= +golang.org/x/crypto v0.25.0/go.mod h1:T+wALwcMOSE0kXgUAnPAHqTLW+XHgcELELW8VaDgm/M= +golang.org/x/mod v0.2.0/go.mod h1:s0Qsj1ACt9ePp/hMypM3fl4fZqREWJwdYDEqhRiZZUA= +golang.org/x/mod v0.3.0/go.mod h1:s0Qsj1ACt9ePp/hMypM3fl4fZqREWJwdYDEqhRiZZUA= golang.org/x/mod v0.4.2/go.mod h1:s0Qsj1ACt9ePp/hMypM3fl4fZqREWJwdYDEqhRiZZUA= golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91VN4djpZkiMVwK6gcyfeH4XE8wZrZaV4= golang.org/x/mod v0.7.0/go.mod h1:iBbtSCu2XBx23ZKBPSOrRkjjQPZFPuis4dIYUhu/chs= -golang.org/x/mod v0.14.0 h1:dGoOF9QVLYng8IHTm7BAyWqCqSheQ5pYWGhzW00YJr0= -golang.org/x/mod v0.14.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= +golang.org/x/mod v0.20.0 h1:utOm6MM3R3dnawAiJgn0y+xvuYRsm1RKM/4giyfDgV0= golang.org/x/mod v0.20.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= +golang.org/x/net v0.0.0-20200226121028-0de0cce0169b/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= +golang.org/x/net v0.0.0-20201021035429-f5854403a974/go.mod h1:sp8m0HH+o8qH0wwXwYZr8TS3Oi6o0r6Gce1SSxlDquU= golang.org/x/net v0.0.0-20210226172049-e18ecbb05110/go.mod h1:m0MpNAwzfU5UDzcl9v0D8zg8gWTRqZa9RBIspLL5mdg= golang.org/x/net v0.0.0-20210405180319-a5a99cb37ef4/go.mod h1:p54w0d4576C0XHj96bSt6lcn1PtDYWL6XObtHCRCNQM= golang.org/x/net v0.0.0-20220722155237-a158d28d115b/go.mod h1:XRhObCWvk6IyKnWLug+ECip1KBveYUHfp+8e9klMJ9c= golang.org/x/net v0.3.0/go.mod h1:MBQ8lrhLObU/6UmLb4fmbmk5OcyYmqtbGd/9yIeKjEE= +golang.org/x/net v0.27.0 h1:5K3Njcw06/l2y9vpGCSdcxWOYHOUk3dVNGDXN+FvAys= +golang.org/x/net v0.27.0/go.mod h1:dDi0PyhWNoiUOrAS8uXv/vnScO4wnHQO4mj9fn/RytE= golang.org/x/sync v0.0.0-20190423024810-112230192c58/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= +golang.org/x/sync v0.0.0-20190911185100-cd5d95a43a6e/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= +golang.org/x/sync v0.0.0-20201020160332-67f06af15bc9/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20210220032951-036812b2e83c/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20220722155255-886fb9371eb4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.1.0/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= -golang.org/x/sync v0.5.0 h1:60k92dhOjHxJkrqnwsfl8KuaHbn/5dl0lUPUklKo3qE= -golang.org/x/sync v0.5.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= +golang.org/x/sync v0.8.0 h1:3NFvSEYkUoMifnESzZl15y791HH1qU2xm6eCJU5ZPXQ= golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20180823144017-11551d06cbcc/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20190916202348-b4ddaad3f8a3/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20191026070338-33540a1f6037/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20200930185726-fdedc70b468f/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20201119102817-f84b799fce68/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20201204225414-ed752295db88/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210124154548-22da62e12c0c/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210330210617-4fbd30eecc44/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210510120138-977fb7262007/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= @@ -171,8 +264,10 @@ golang.org/x/sys v0.0.0-20220520151302-bc2c85ada10a/go.mod h1:oPkhp1MJrh7nUepCBc golang.org/x/sys v0.0.0-20220627191245-f75cf1eec38b/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.0.0-20220722155257-8c9f86f7a55f/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.3.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= -golang.org/x/sys v0.20.0 h1:Od9JTbYCk261bKm4M/mw7AklTlFYIa0bIp9BgSm1S8Y= -golang.org/x/sys v0.20.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.8.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= +golang.org/x/sys v0.11.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= +golang.org/x/sys v0.19.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.23.0 h1:YfKFowiIMvtgl1UERQoTPPToxltDeZfbj4H7dVUCwmM= golang.org/x/sys v0.23.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210927222741-03fcf44c2211/go.mod h1:jbD1KX2456YbFQfuXm/mYQcufACuNUgVhRMnK/tPxf8= @@ -181,16 +276,18 @@ golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= golang.org/x/text v0.3.3/go.mod h1:5Zoc/QRtKVWzQhOtBMvqHzDpF6irO9z98xDceosuGiQ= golang.org/x/text v0.3.7/go.mod h1:u+2+/6zg+i71rQMx5EYifcz6MCKuco9NR6JIITiCfzQ= golang.org/x/text v0.5.0/go.mod h1:mrYo+phRRbMaCq/xk9113O4dZlRixOauAjOtrjsXDZ8= -golang.org/x/time v0.3.0 h1:rg5rLMjNzMS1RkNLzCG38eapWhnYLFYXDXj2gOlr8j4= -golang.org/x/time v0.3.0/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= +golang.org/x/text v0.16.0 h1:a94ExnEXNtEwYLGJSIUxnWoxoRz/ZcCsV63ROupILh4= +golang.org/x/text v0.16.0/go.mod h1:GhwF1Be+LQoKShO3cGOHzqOgRrGaYc9AvblQOmPVHnI= +golang.org/x/time v0.6.0 h1:eTDhh4ZXt5Qf0augr54TN6suAUudPcawVZeIAPU7D4U= golang.org/x/time v0.6.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20191119224855-298f0cb1881e/go.mod h1:b+2E5dAYhXwXZwtnZ6UAqBI28+e2cm9otk0dWdXHAEo= +golang.org/x/tools v0.0.0-20200619180055-7c47624df98f/go.mod h1:EkVYQZoAsY45+roYkvgYkIh4xh/qjgUK9TdY2XT94GE= +golang.org/x/tools v0.0.0-20210106214847-113979e3529a/go.mod h1:emZCQorbCU4vsT4fOWvOPXz4eW1wZW4PmDk9uLelYpA= golang.org/x/tools v0.1.1/go.mod h1:o0xws9oXOQQZyjljx8fwUC0k7L1pTE6eaCbjGeHmOkk= golang.org/x/tools v0.1.12/go.mod h1:hNGJHUnrk76NpqgfD5Aqm5Crs+Hm0VOH/i9J2+nxYbc= golang.org/x/tools v0.4.0/go.mod h1:UE5sM2OK9E/d67R0ANs2xJizIymRP5gJU295PvKXxjQ= -golang.org/x/tools v0.16.1 h1:TLyB3WofjdOEepBHAU20JdNC1Zbg87elYofWYAY5oZA= -golang.org/x/tools v0.16.1/go.mod h1:kYVVN6I1mBNoB1OX+noeBjbRk4IUEPa7JJ+TJMEooJ0= +golang.org/x/tools v0.23.0 h1:SGsXPZ+2l4JsgaCKkx+FQ9YZ5XEtA1GZYuoDjenLjvg= golang.org/x/tools v0.23.0/go.mod h1:pnu6ufv6vQkll6szChhK3C3L/ruaIv5eBeztNG8wtsI= golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191011141410-1b5146add898/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= @@ -198,18 +295,24 @@ golang.org/x/xerrors v0.0.0-20191204190536-9bdfabe68543/go.mod h1:I/5z698sn9Ka8T golang.org/x/xerrors v0.0.0-20200804184101-5ec99f83aff1/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 h1:+cNy6SZtPcJQH3LJVLOSmiC7MMxXNOb3PU/VUEz+EhU= golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028/go.mod h1:NDW/Ps6MPRej6fsCIbMTohpP40sJ/P/vI1MoTEGwX90= -google.golang.org/grpc v1.57.1 h1:upNTNqv0ES+2ZOOqACwVtS3Il8M12/+Hz41RCPzAjQg= -google.golang.org/grpc v1.57.1/go.mod h1:Sd+9RMTACXwmub0zcNY2c4arhtrbBYD1AUHI/dt16Mo= +google.golang.org/appengine v1.6.8 h1:IhEN5q69dyKagZPYMSdIjS2HqprW324FRQZJcGqPAsM= +google.golang.org/appengine v1.6.8/go.mod h1:1jJ3jBArFh5pcgW8gCtRJnepW8FzD1V44FJffLiz/Ds= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 h1:Q2RxlXqh1cgzzUgV261vBO2jI5R/3DD1J2pM0nI4NhU= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5/go.mod h1:EfXuqaE1J41VCDicxHzUDm+8rk+7ZdXzHV0IhO/I6s0= +google.golang.org/grpc v1.64.0 h1:KH3VH9y/MgNQg1dE7b3XfVK0GsPSIzJwdF617gUSbvY= +google.golang.org/grpc v1.64.0/go.mod h1:oxjF8E3FBnjp+/gVFYdWacaLDx9na1aqy9oovLpxQYg= google.golang.org/protobuf v1.26.0-rc.1/go.mod h1:jlhhOSvTdKEhbULTjvd4ARK9grFBp09yW+WbY/TyQbw= -google.golang.org/protobuf v1.33.0 h1:uNO2rsAINq/JlFpSdYEKIZ0uKD/R9cpdv0T+yoGwGmI= google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= +google.golang.org/protobuf v1.34.2 h1:6xV6lTsCfpGD21XK49h7MhtcApnLqkfYgPcdHftf6hg= google.golang.org/protobuf v1.34.2/go.mod h1:qYOHts0dSfpeUzUFpOMr/WGzszTmLH+DiWniOlNbLDw= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= -gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c h1:Hei/4ADfdWqJk1ZMxUNpqntNwaWcugrBjAiHlqqRiVk= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c/go.mod h1:JHkPIbrfpd72SG/EVd6muEfDQjcINNoR0C8j2r3qZ4Q= -gopkg.in/errgo.v2 v2.1.0/go.mod h1:hNsd1EY+bozCKY1Ytp96fpM3vjJbqLJn88ws8XvfDNI= +gopkg.in/ini.v1 v1.67.0 h1:Dgnx+6+nfE+IfzjUEISNeydPJh9AXNNsWbGP9KzCsOA= +gopkg.in/ini.v1 v1.67.0/go.mod h1:pNLf8WUiyNEtQjuu5G5vTm06TEv9tsIgeAvK8hOrP4k= gopkg.in/yaml.v2 v2.2.2/go.mod h1:hI93XBmqTisBFMUTm0b8Fm+jr3Dg1NNxqwp+5A1VGuI= +gopkg.in/yaml.v2 v2.4.0 h1:D8xgwECY7CYvx+Y2n4sBz93Jn9JRvxdiyyo8CTfuKaY= +gopkg.in/yaml.v2 v2.4.0/go.mod h1:RDklbk79AGWmwhnvt/jBztapEOGDOx6ZbXqjP6csGnQ= gopkg.in/yaml.v3 v3.0.0-20200313102051-9f266ea9e77c/go.mod h1:K4uyk7z7BCEPqu6E+C64Yfv1cQ7kz7rIZviUmN+EgEM= gopkg.in/yaml.v3 v3.0.1 h1:fxVm/GzAzEWqLHuvctI91KS9hhNmmWOoWu0XTYJS7CA= gopkg.in/yaml.v3 v3.0.1/go.mod h1:K4uyk7z7BCEPqu6E+C64Yfv1cQ7kz7rIZviUmN+EgEM= diff --git a/internal/exectracetest/go.mod b/internal/exectracetest/go.mod index a690ce9611..4e0d754435 100644 --- a/internal/exectracetest/go.mod +++ b/internal/exectracetest/go.mod @@ -12,29 +12,64 @@ require ( require ( github.com/DataDog/appsec-internal-go v1.7.0 // indirect github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 // indirect github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 // indirect github.com/DataDog/datadog-go/v5 v5.5.0 // indirect github.com/DataDog/go-libddwaf/v3 v3.3.0 // indirect + github.com/DataDog/go-sqllexer v0.0.13 // indirect github.com/DataDog/go-tuf v1.1.0-0.5.2 // indirect + github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0 // indirect github.com/DataDog/sketches-go v1.4.5 // indirect github.com/Microsoft/go-winio v0.6.1 // indirect github.com/cespare/xxhash/v2 v2.3.0 // indirect + github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575 // indirect github.com/dustin/go-humanize v1.0.1 // indirect github.com/ebitengine/purego v0.6.0-alpha.5 // indirect + github.com/go-ole/go-ole v1.2.6 // indirect + github.com/gogo/protobuf v1.3.2 // indirect + github.com/golang/protobuf v1.5.4 // indirect github.com/google/uuid v1.6.0 // indirect + github.com/json-iterator/go v1.1.12 // indirect + github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c // indirect + github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd // indirect + github.com/modern-go/reflect2 v1.0.2 // indirect github.com/outcaste-io/ristretto v0.2.3 // indirect github.com/philhofer/fwd v1.1.2 // indirect github.com/pkg/errors v0.9.1 // indirect + github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c // indirect github.com/secure-systems-lab/go-securesystemslib v0.7.0 // indirect + github.com/shirou/gopsutil/v3 v3.24.4 // indirect + github.com/shoenig/go-m1cpu v0.1.6 // indirect github.com/tinylib/msgp v1.1.8 // indirect + github.com/tklauser/go-sysconf v0.3.12 // indirect + github.com/tklauser/numcpus v0.6.1 // indirect + github.com/yusufpapurcu/wmi v1.2.4 // indirect + go.opentelemetry.io/collector/component v0.104.0 // indirect + go.opentelemetry.io/collector/config/configtelemetry v0.104.0 // indirect + go.opentelemetry.io/collector/pdata v1.11.0 // indirect + go.opentelemetry.io/collector/semconv v0.104.0 // indirect + go.opentelemetry.io/otel v1.27.0 // indirect + go.opentelemetry.io/otel/metric v1.27.0 // indirect + go.opentelemetry.io/otel/trace v1.27.0 // indirect go.uber.org/atomic v1.11.0 // indirect + go.uber.org/multierr v1.11.0 // indirect + go.uber.org/zap v1.27.0 // indirect golang.org/x/mod v0.20.0 // indirect + golang.org/x/net v0.27.0 // indirect golang.org/x/sync v0.8.0 // indirect golang.org/x/sys v0.23.0 // indirect + golang.org/x/text v0.16.0 // indirect golang.org/x/time v0.6.0 // indirect golang.org/x/tools v0.23.0 // indirect golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 // indirect + google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 // indirect + google.golang.org/grpc v1.64.0 // indirect google.golang.org/protobuf v1.34.2 // indirect + gopkg.in/ini.v1 v1.67.0 // indirect + gopkg.in/yaml.v2 v2.4.0 // indirect ) // use local version of dd-trace-go diff --git a/internal/exectracetest/go.sum b/internal/exectracetest/go.sum index 1802647eda..33c364027c 100644 --- a/internal/exectracetest/go.sum +++ b/internal/exectracetest/go.sum @@ -1,38 +1,50 @@ github.com/DataDog/appsec-internal-go v1.7.0 h1:iKRNLih83dJeVya3IoUfK+6HLD/hQsIbyBlfvLmAeb0= github.com/DataDog/appsec-internal-go v1.7.0/go.mod h1:wW0cRfWBo4C044jHGwYiyh5moQV2x0AhnwqMuiX7O/g= -github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0 h1:bUMSNsw1iofWiju9yc1f+kBd33E3hMJtq9GuU602Iy8= -github.com/DataDog/datadog-agent/pkg/obfuscate v0.48.0/go.mod h1:HzySONXnAgSmIQfL6gOv9hWprKJkx8CicuXuUbmgWfo= +github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 h1:18/yZ0yKjCnTPkBW7K8LdRiRiVaYjKF0yE1QHfMA7yI= github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1/go.mod h1:T+qq8YiHRRIuB9A1W1k9KE4Owr9anljl12Ztm7Nx8XU= -github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1 h1:5nE6N3JSs2IG3xzMthNFhXfOaXlrsdgqmJ73lndFf8c= -github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.48.1/go.mod h1:Vc+snp0Bey4MrrJyiV2tVxxJb6BmLomPvN1RgAvjGaQ= +github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 h1:qq3MUh7MdkywBpjm0HRaYOfcunNemWI+wO4u2w1GWnA= +github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1/go.mod h1:5h7i2YkGEM4QOu4TUaYeSPZ1BeuXaseA276cCrSvCmM= +github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 h1:hVa76HpVox8Xt05qpLuqAngd9+1waSA5IVQqCFJ2RPQ= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= -github.com/DataDog/datadog-go/v5 v5.3.0 h1:2q2qjFOb3RwAZNU+ez27ZVDwErJv5/VpbBPprz7Z+s8= -github.com/DataDog/datadog-go/v5 v5.3.0/go.mod h1:XRDJk1pTc00gm+ZDiBKsjh7oOOtJfYfglVCmFb8C2+Q= +github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 h1:iMJU0lqQvrpJ6LCLTWwbUlCWaazurhwwvWf8FKsaOs4= +github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1/go.mod h1:RdepkDr3A0tJ6G/B4MfMy1fzEYHovykN7pnXOK1vePg= +github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 h1:Bx5kkulMNaTgNH8/Piu0wpwOhd4BZR7Ht0SMv4zAKQg= +github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1/go.mod h1:S/D5aNZadFQk6IWKghTnuiKVyD+9OfSfsm116VY+xlU= +github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 h1:7IY8ST69RNo+x7Z2Y99BtsLPqFyTZWTh9LWWFYQBr3A= +github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1/go.mod h1:8ASCNWHQtcmUedxL+WjbCPSIcGIM8LeVzil7JCzx0js= +github.com/DataDog/datadog-go/v5 v5.5.0 h1:G5KHeB8pWBNXT4Jtw0zAkhdxEAWSpWH00geHI6LDrKU= github.com/DataDog/datadog-go/v5 v5.5.0/go.mod h1:K9kcYBlxkcPP8tvvjZZKs/m1edNAUFzBbdpTUKfCsuw= github.com/DataDog/go-libddwaf/v3 v3.3.0 h1:jS72fuQpFgJZEdEJDmHJCPAgNTEMZoz1EUvimPUOiJ4= github.com/DataDog/go-libddwaf/v3 v3.3.0/go.mod h1:Bz/0JkpGf689mzbUjKJeheJINqsyyhM8p9PDuHdK2Ec= -github.com/DataDog/go-tuf v1.0.2-0.5.2 h1:EeZr937eKAWPxJ26IykAdWA4A0jQXJgkhUjqEI/w7+I= -github.com/DataDog/go-tuf v1.0.2-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= +github.com/DataDog/go-sqllexer v0.0.13 h1:9mKfe+3s73GI/7dWBxi2Ds7+xZynJqMKK9cIUBrutak= +github.com/DataDog/go-sqllexer v0.0.13/go.mod h1:KwkYhpFEVIq+BfobkTC1vfqm4gTi65skV/DpDBXtexc= +github.com/DataDog/go-tuf v1.1.0-0.5.2 h1:4CagiIekonLSfL8GMHRHcHudo1fQnxELS9g4tiAupQ4= github.com/DataDog/go-tuf v1.1.0-0.5.2/go.mod h1:zBcq6f654iVqmkk8n2Cx81E1JnNTMOAx1UEO/wZR+P0= github.com/DataDog/gostackparse v0.7.0 h1:i7dLkXHvYzHV308hnkvVGDL3BR4FWl7IsXNPz/IGQh4= github.com/DataDog/gostackparse v0.7.0/go.mod h1:lTfqcJKqS9KnXQGnyQMCugq3u1FP6UZMfWR0aitKFMM= +github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0 h1:10TPqpTlIkmDPFWVIEZ4ZX3rWrCrx3rEoeoAooZr6LM= +github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0/go.mod h1:dvIWN9pA2zWNTw5rhDWZgzZnhcfpH++d+8d1SWW6xkY= github.com/DataDog/sketches-go v1.4.5 h1:ki7VfeNz7IcNafq7yI/j5U/YCkO3LJiMDtXz9OMQbyE= github.com/DataDog/sketches-go v1.4.5/go.mod h1:7Y8GN8Jf66DLyDhc94zuWA3uHEt/7ttt8jHOBWWrSOg= github.com/Microsoft/go-winio v0.5.0/go.mod h1:JPGBdM1cNvN/6ISo+n8V5iA4v8pBzdOpzfwIujj1a84= github.com/Microsoft/go-winio v0.6.1 h1:9/kr64B9VUZrLm5YYwbGtUJnMgqWVOdUAXu6Migciow= github.com/Microsoft/go-winio v0.6.1/go.mod h1:LRdKpFKfdobln8UmuiYcKPot9D2v6svN5+sAH+4kjUM= +github.com/beorn7/perks v1.0.1 h1:VlbKKnNfV8bJzeqoa4cOKqO6bYr3WgKZxO8Z16+hsOM= +github.com/beorn7/perks v1.0.1/go.mod h1:G2ZrVWU2WbWT9wwq4/hrbKbnv/1ERSJQ0ibhJ6rlkpw= github.com/cespare/xxhash/v2 v2.1.1/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= -github.com/cespare/xxhash/v2 v2.2.0 h1:DC2CZ1Ep5Y4k3ZQ899DldepgrayRUGE6BBZ/cd9Cj44= -github.com/cespare/xxhash/v2 v2.2.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= +github.com/cespare/xxhash/v2 v2.3.0 h1:UL815xU9SqsFlibzuggzjXhog7bL6oX9BbNZnL2UFvs= github.com/cespare/xxhash/v2 v2.3.0/go.mod h1:VGX0DQ3Q6kWi7AoAeZDth3/j3BFtOZR5XLFGgcrjCOs= +github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575 h1:kHaBemcxl8o/pQ5VM1c8PVE1PubbNx3mjUr09OqWGCs= +github.com/cihub/seelog v0.0.0-20170130134532-f561c5e57575/go.mod h1:9d6lWj8KzO/fd/NrVaLscBKmPigpZpn5YawRPw+e3Yo= github.com/davecgh/go-spew v1.1.0/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.1/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc h1:U9qPSI2PIWSS1VwoXQT9A3Wy9MM3WgvqSxFWenqJduM= github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/denisenkom/go-mssqldb v0.11.0 h1:9rHa233rhdOyrz2GcP9NM+gi2psgJZ4GWDpL/7ND8HI= github.com/denisenkom/go-mssqldb v0.11.0/go.mod h1:xbL0rPBG9cCiLr28tMa8zpbdarY27NDyej4t/EjAShU= -github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2 h1:tdlZCpZ/P9DhczCTSixgIKmwPv6+wP5DGjqLYw5SUiA= github.com/dgryski/go-farm v0.0.0-20190423205320-6a90982ecee2/go.mod h1:SqUrOPUnsFjfmXRMNPybcSiG0BgUW2AuFH8PAnS2iTw= +github.com/dgryski/go-farm v0.0.0-20200201041132-a6ae2369ad13 h1:fAjc9m62+UWV/WAFKLNi6ZS0675eEUC9y3AlwSbQu1Y= +github.com/dgryski/go-farm v0.0.0-20200201041132-a6ae2369ad13/go.mod h1:SqUrOPUnsFjfmXRMNPybcSiG0BgUW2AuFH8PAnS2iTw= github.com/dustin/go-humanize v1.0.0/go.mod h1:HtrtbFcZ19U5GC7JDqmcUSB87Iq5E25KnS6fMYU6eOk= github.com/dustin/go-humanize v1.0.1 h1:GzkhY7T5VNhEkwH0PVJgjz+fX1rhBrR7pRT3mDkpeCY= github.com/dustin/go-humanize v1.0.1/go.mod h1:Mu1zIs6XwVuF/gI1OepvI0qD18qycQx+mFykh5fBlto= @@ -43,19 +55,31 @@ github.com/ebitengine/purego v0.6.0-alpha.5 h1:EYID3JOAdmQ4SNZYJHu9V6IqOeRQDBYxq github.com/ebitengine/purego v0.6.0-alpha.5/go.mod h1:ah1In8AOtksoNK6yk5z1HTJeUkC1Ez4Wk2idgGslMwQ= github.com/glebarez/go-sqlite v1.22.0 h1:uAcMJhaA6r3LHMTFgP0SifzgXg46yJkgxqyuyec+ruQ= github.com/glebarez/go-sqlite v1.22.0/go.mod h1:PlBIdHe0+aUEFn+r2/uthrWq4FxbzugL0L8Li6yQJbc= +github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= +github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= +github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= +github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= +github.com/go-ole/go-ole v1.2.6 h1:/Fpf6oFPoeFik9ty7siob0G6Ke8QvQEuVcuChpwXzpY= +github.com/go-ole/go-ole v1.2.6/go.mod h1:pprOEPIfldk/42T2oK7lQ4v4JSDwmV0As9GaiUsvbm0= github.com/go-sql-driver/mysql v1.6.0 h1:BCTh4TKNUYmOmMUcQ3IipzF5prigylS7XXjEkfCHuOE= github.com/go-sql-driver/mysql v1.6.0/go.mod h1:DCzpHaOWr8IXmIStZouvnhqoel9Qv2LBy8hT2VhHyBg= +github.com/gogo/protobuf v1.3.2 h1:Ov1cvc58UF3b5XjBnZv7+opcTcQFZebYjWzi34vdm4Q= +github.com/gogo/protobuf v1.3.2/go.mod h1:P1XiOD3dCwIKUDQYPy72D8LYyHL2YPYrpS2s69NZV8Q= github.com/golang-sql/civil v0.0.0-20220223132316-b832511892a9 h1:au07oEsX2xN0ktxqI+Sida1w446QrXBRJ0nee3SNZlA= github.com/golang-sql/civil v0.0.0-20220223132316-b832511892a9/go.mod h1:8vg3r2VgvsThLBIFL93Qb5yWzgyZWhEmBwUJWevAkK0= github.com/golang/mock v1.6.0/go.mod h1:p6yTPP+5HYm5mzsMV8JkE6ZKdX+/wYM6Hr+LicevLPs= +github.com/golang/protobuf v1.5.4 h1:i7eJL8qZTpSEXOPTxNKhASYpMn+8e5Q6AdndVa1dWek= +github.com/golang/protobuf v1.5.4/go.mod h1:lnTiLA8Wa4RWRcIUkrtSVa5nRhsEGBg48fD6rSs7xps= +github.com/google/go-cmp v0.5.6/go.mod h1:v8dTdLbMG2kIc/vJvl+f65V22dbkXbowE6jgT/gNBxE= +github.com/google/go-cmp v0.5.9/go.mod h1:17dUlkBOakJ0+DkrSSNjCkIjxS6bF9zb3elmeNGIjoY= github.com/google/go-cmp v0.6.0 h1:ofyhxvXcZhMsU5ulbFiLKl/XBFqE1GSq7atu8tAmTRI= github.com/google/go-cmp v0.6.0/go.mod h1:17dUlkBOakJ0+DkrSSNjCkIjxS6bF9zb3elmeNGIjoY= +github.com/google/gofuzz v1.0.0/go.mod h1:dBl0BpW6vV/+mYPU4Po3pmUjxk6FQPldtuIdl/M65Eg= github.com/google/gofuzz v1.2.0 h1:xRy4A+RhZaiKjJ1bPfwQ8sedCA+YS2YcCHW6ec7JMi0= github.com/google/gofuzz v1.2.0/go.mod h1:dBl0BpW6vV/+mYPU4Po3pmUjxk6FQPldtuIdl/M65Eg= github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b h1:h9U78+dx9a4BKdQkBBos92HalKpaGKHrp+3Uo6yTodo= github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b/go.mod h1:czg5+yv1E0ZGTi6S6vVK1mke0fV+FaUhNGcd6VRS9Ik= -github.com/google/uuid v1.5.0 h1:1p67kYwdtXjb0gL0BPiP1Av9wiZPo5A8z2cWkTZ+eyU= -github.com/google/uuid v1.5.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= +github.com/google/uuid v1.6.0 h1:NIvaJDMOsjHA8n1jAhLSgzrAzy1Hgr+hNrb57e+94F0= github.com/google/uuid v1.6.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/hashicorp/go-secure-stdlib/parseutil v0.1.7 h1:UpiO20jno/eV1eVZcxqWnUohyKRe1g8FPV/xH1s/2qs= github.com/hashicorp/go-secure-stdlib/parseutil v0.1.7/go.mod h1:QmrqtbKuxxSWTN3ETMPuB+VtEiBJ/A9XhoYGv8E1uD8= @@ -63,18 +87,30 @@ github.com/hashicorp/go-secure-stdlib/strutil v0.1.2 h1:kes8mmyCpxJsI7FTwtzRqEy9 github.com/hashicorp/go-secure-stdlib/strutil v0.1.2/go.mod h1:Gou2R9+il93BqX25LAKCLuM+y9U2T4hlwvT1yprcna4= github.com/hashicorp/go-sockaddr v1.0.2 h1:ztczhD1jLxIRjVejw8gFomI1BQZOe2WoVOu0SyteCQc= github.com/hashicorp/go-sockaddr v1.0.2/go.mod h1:rB4wwRAUzs07qva3c5SdrY/NEtAUjGlgmH/UkBUC97A= -github.com/kr/pretty v0.2.1 h1:Fmg33tUaq4/8ym9TJN1x7sLJnHVwhP33CNkpYV/7rwI= -github.com/kr/pretty v0.2.1/go.mod h1:ipq/a2n7PKx3OHsz4KJII5eveXtPO4qwEXGdVfWzfnI= +github.com/json-iterator/go v1.1.12 h1:PV8peI4a0ysnczrg+LtxykD8LfKY9ML6u2jnxaEnrnM= +github.com/json-iterator/go v1.1.12/go.mod h1:e30LSqwooZae/UwlEbR2852Gd8hjQvJoHmT4TnhNGBo= +github.com/kisielk/errcheck v1.5.0/go.mod h1:pFxgyoBC7bSaBwPgfKdkLd5X25qrDl4LWUI2bnpBCr8= +github.com/kisielk/gotool v1.0.0/go.mod h1:XhKaO+MFFWcvkIS/tQcRk01m1F5IRFswLeQ+oQHNcck= +github.com/kr/pretty v0.3.1 h1:flRD4NNwYAUpkphVc1HcthR4KEIFJ65n8Mw5qdRn3LE= +github.com/kr/pretty v0.3.1/go.mod h1:hoEshYVHaxMs3cyo3Yncou5ZscifuDolrwPKZanG3xk= github.com/kr/text v0.2.0 h1:5Nx0Ya0ZqY2ygV366QzturHI13Jq95ApcVaJBhpS+AY= github.com/kr/text v0.2.0/go.mod h1:eLer722TekiGuMkidMxC/pM04lWEeraHUUmBw8l2grE= github.com/lib/pq v1.10.2 h1:AqzbZs4ZoCBp+GtejcpCpcxM3zlSMx29dXbUSeVtJb8= github.com/lib/pq v1.10.2/go.mod h1:AlVN5x4E4T544tWzH6hKfbfQvm3HdbOxrmggDNAPY9o= +github.com/lufia/plan9stats v0.0.0-20211012122336-39d0f177ccd0/go.mod h1:zJYVVT2jmtg6P3p1VtQj7WsuWi/y4VnjVBn7F8KPB3I= +github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c h1:VtwQ41oftZwlMnOEbMWQtSEUgU64U4s+GHk7hZK+jtY= +github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c/go.mod h1:JKx41uQRwqlTZabZc+kILPrO/3jlKnQ2Z8b7YiVw5cE= github.com/mattn/go-isatty v0.0.20 h1:xfD0iDuEKnDkl03q4limB+vH+GxLEtL/jb4xVJSWWEY= github.com/mattn/go-isatty v0.0.20/go.mod h1:W+V8PltTTMOvKvAeJH7IuucS94S2C6jfK/D7dTCTo3Y= github.com/mattn/go-sqlite3 v1.14.18 h1:JL0eqdCOq6DJVNPSvArO/bIV9/P7fbGrV00LZHc+5aI= github.com/mattn/go-sqlite3 v1.14.18/go.mod h1:2eHXhiwb8IkHr+BDWZGa96P6+rkvnG63S2DGjv9HUNg= -github.com/mitchellh/mapstructure v1.5.0 h1:jeMsZIYE/09sWLaz43PL7Gy6RuMjD2eJVyuac5Z2hdY= -github.com/mitchellh/mapstructure v1.5.0/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= +github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c h1:cqn374mizHuIWj+OSJCajGr/phAmuMug9qIX3l9CflE= +github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c/go.mod h1:bFUtVrKA4DC2yAKiSyO/QUcy7e+RRV2QTWOzhPopBRo= +github.com/modern-go/concurrent v0.0.0-20180228061459-e0a39a4cb421/go.mod h1:6dJC0mAP4ikYIbvyc7fijjWJddQyLn8Ig3JB5CqoB9Q= +github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd h1:TRLaZ9cD/w8PVh93nsPXa1VrQ6jlwL5oN8l14QlcNfg= +github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd/go.mod h1:6dJC0mAP4ikYIbvyc7fijjWJddQyLn8Ig3JB5CqoB9Q= +github.com/modern-go/reflect2 v1.0.2 h1:xBagoLtFs94CBntxluKeaWgTMpvLxC4ur3nMaC9Gz0M= +github.com/modern-go/reflect2 v1.0.2/go.mod h1:yWuevngMOJpCy52FWWMvUC8ws7m/LJsjYzDa0/r8luk= github.com/opentracing/opentracing-go v1.2.0 h1:uEJPy/1a5RIPAJ0Ov+OIO8OxWu77jEv+1B0VhjKrZUs= github.com/opentracing/opentracing-go v1.2.0/go.mod h1:GxEUsuufX4nBwe+T+Wl9TAgYrxe9dPLANfrWvHYVTgc= github.com/outcaste-io/ristretto v0.2.3 h1:AK4zt/fJ76kjlYObOeNwh4T3asEuaCmp26pOvUOL9w0= @@ -86,14 +122,33 @@ github.com/pkg/errors v0.9.1/go.mod h1:bwawxfHBFNV+L2hUp1rHADufV3IMtnDRdf1r5NINE github.com/pmezard/go-difflib v1.0.0/go.mod h1:iKH77koFhYxTK1pcRnkKkqfTogsbg7gZNVY4sRDYZ/4= github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2 h1:Jamvg5psRIccs7FGNTlIRMkT8wgtp5eCXdBlqhYGL6U= github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2/go.mod h1:iKH77koFhYxTK1pcRnkKkqfTogsbg7gZNVY4sRDYZ/4= +github.com/power-devops/perfstat v0.0.0-20210106213030-5aafc221ea8c/go.mod h1:OmDBASR4679mdNQnz2pUhc2G8CO2JrUAVFDRBDP/hJE= +github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c h1:NRoLoZvkBTKvR5gQLgA3e0hqjkY9u1wm+iOL45VN/qI= +github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c/go.mod h1:OmDBASR4679mdNQnz2pUhc2G8CO2JrUAVFDRBDP/hJE= +github.com/prometheus/client_golang v1.19.1 h1:wZWJDwK+NameRJuPGDhlnFgx8e8HN3XHQeLaYJFJBOE= +github.com/prometheus/client_golang v1.19.1/go.mod h1:mP78NwGzrVks5S2H6ab8+ZZGJLZUq1hoULYBAYBw1Ho= +github.com/prometheus/client_model v0.6.1 h1:ZKSh/rekM+n3CeS952MLRAdFwIKqeY8b62p8ais2e9E= +github.com/prometheus/client_model v0.6.1/go.mod h1:OrxVMOVHjw3lKMa8+x6HeMGkHMQyHDk9E3jmP2AmGiY= +github.com/prometheus/common v0.54.0 h1:ZlZy0BgJhTwVZUn7dLOkwCZHUkrAqd3WYtcFCWnM1D8= +github.com/prometheus/common v0.54.0/go.mod h1:/TQgMJP5CuVYveyT7n/0Ix8yLNNXy9yRSkhnLTHPDIQ= +github.com/prometheus/procfs v0.15.0 h1:A82kmvXJq2jTu5YUhSGNlYoxh85zLnKgPz4bMZgI5Ek= +github.com/prometheus/procfs v0.15.0/go.mod h1:Y0RJ/Y5g5wJpkTisOtqwDSo4HwhGmLB4VQSw2sQJLHk= github.com/remyoudompheng/bigfft v0.0.0-20230129092748-24d4a6f8daec h1:W09IVJc94icq4NjY3clb7Lk8O1qJ8BdBEF8z0ibU0rE= github.com/remyoudompheng/bigfft v0.0.0-20230129092748-24d4a6f8daec/go.mod h1:qqbHyh8v60DhA7CoWK5oRCqLrMHRGoxYCSS9EjAz6Eo= github.com/richardartoul/molecule v1.0.1-0.20240531184615-7ca0df43c0b3 h1:4+LEVOB87y175cLJC/mbsgKmoDOjrBldtXvioEy96WY= github.com/richardartoul/molecule v1.0.1-0.20240531184615-7ca0df43c0b3/go.mod h1:vl5+MqJ1nBINuSsUI2mGgH79UweUT/B5Fy8857PqyyI= +github.com/rogpeppe/go-internal v1.10.0 h1:TMyTOH3F/DB16zRVcYyreMH6GnZZrwQVAoYjRBZyWFQ= +github.com/rogpeppe/go-internal v1.10.0/go.mod h1:UQnix2H7Ngw/k4C5ijL5+65zddjncjaFoBhdsK/akog= github.com/ryanuber/go-glob v1.0.0 h1:iQh3xXAumdQ+4Ufa5b25cRpC5TYKlno6hsv6Cb3pkBk= github.com/ryanuber/go-glob v1.0.0/go.mod h1:807d1WSdnB0XRJzKNil9Om6lcp/3a0v4qIHxIXzX/Yc= github.com/secure-systems-lab/go-securesystemslib v0.7.0 h1:OwvJ5jQf9LnIAS83waAjPbcMsODrTQUpJ02eNLUoxBg= github.com/secure-systems-lab/go-securesystemslib v0.7.0/go.mod h1:/2gYnlnHVQ6xeGtfIqFy7Do03K4cdCY0A/GlJLDKLHI= +github.com/shirou/gopsutil/v3 v3.24.4 h1:dEHgzZXt4LMNm+oYELpzl9YCqV65Yr/6SfrvgRBtXeU= +github.com/shirou/gopsutil/v3 v3.24.4/go.mod h1:lTd2mdiOspcqLgAnr9/nGi71NkeMpWKdmhuxm9GusH8= +github.com/shoenig/go-m1cpu v0.1.6 h1:nxdKQNcEB6vzgA2E2bvzKIYRuNj7XNJ4S/aRSwKzFtM= +github.com/shoenig/go-m1cpu v0.1.6/go.mod h1:1JJMcUBvfNwpq05QDQVAnx3gUHr9IYF7GNg9SUEw2VQ= +github.com/shoenig/test v0.6.4 h1:kVTaSd7WLz5WZ2IaoM0RSzRsUD+m8wRR+5qvntpn4LU= +github.com/shoenig/test v0.6.4/go.mod h1:byHiCGXqrVaflBLAMq/srcZIHynQPQgeyvkvXnjqq0k= github.com/sirupsen/logrus v1.7.0/go.mod h1:yWOB1SBYBC5VeMP7gHvWumXLIWorT60ONWic61uBYv0= github.com/spaolacci/murmur3 v1.1.0 h1:7c1g84S4BPRrfL5Xrdp6fOJ206sU9y293DDHaoy0bLI= github.com/spaolacci/murmur3 v1.1.0/go.mod h1:JwIasOWyU6f++ZhiEuf87xNszmSA2myDM2Kzu9HwQUA= @@ -108,47 +163,94 @@ github.com/stretchr/testify v1.7.0/go.mod h1:6Fq8oRcR53rry900zMqJjRRixrwX3KX962/ github.com/stretchr/testify v1.7.1/go.mod h1:6Fq8oRcR53rry900zMqJjRRixrwX3KX962/h/Wwjteg= github.com/stretchr/testify v1.8.0/go.mod h1:yNjHg4UonilssWZ8iaSj1OCr/vHnekPRkoO+kdMU+MU= github.com/stretchr/testify v1.8.1/go.mod h1:w2LPCIKwWwSfY2zedu0+kehJoqGctiVI29o6fzry7u4= +github.com/stretchr/testify v1.8.4/go.mod h1:sz/lmYIOXD/1dqDmKjjqLyZ2RngseejIcXlSw2iwfAo= github.com/stretchr/testify v1.9.0 h1:HtqpIVDClZ4nwg75+f6Lvsy/wHu+3BoSGCbBAcpTsTg= github.com/stretchr/testify v1.9.0/go.mod h1:r2ic/lqez/lEtzL7wO/rwa5dbSLXVDPFyf8C91i36aY= github.com/tinylib/msgp v1.1.8 h1:FCXC1xanKO4I8plpHGH2P7koL/RzZs12l/+r7vakfm0= github.com/tinylib/msgp v1.1.8/go.mod h1:qkpG+2ldGg4xRFmx+jfTvZPxfGFhi64BcnL9vkCm/Tw= +github.com/tklauser/go-sysconf v0.3.12 h1:0QaGUFOdQaIVdPgfITYzaTegZvdCjmYO52cSFAEVmqU= +github.com/tklauser/go-sysconf v0.3.12/go.mod h1:Ho14jnntGE1fpdOqQEEaiKRpvIavV0hSfmBq8nJbHYI= +github.com/tklauser/numcpus v0.6.1 h1:ng9scYS7az0Bk4OZLvrNXNSAO2Pxr1XXRAPyjhIx+Fk= +github.com/tklauser/numcpus v0.6.1/go.mod h1:1XfjsgE2zo8GVw7POkMbHENHzVg3GzmoZ9fESEdAacY= +github.com/vmihailenco/msgpack/v4 v4.3.12 h1:07s4sz9IReOgdikxLTKNbBdqDMLsjPKXwvCazn8G65U= +github.com/vmihailenco/msgpack/v4 v4.3.12/go.mod h1:gborTTJjAo/GWTqqRjrLCn9pgNN+NXzzngzBKDPIqw4= +github.com/vmihailenco/tagparser v0.1.2 h1:gnjoVuB/kljJ5wICEEOpx98oXMWPLj22G67Vbd1qPqc= +github.com/vmihailenco/tagparser v0.1.2/go.mod h1:OeAg3pn3UbLjkWt+rN9oFYB6u/cQgqMEUPoW2WPyhdI= +github.com/yuin/goldmark v1.1.27/go.mod h1:3hX8gzYuyVAZsxl0MRgGTJEmQBFcNTphYh9decYSb74= +github.com/yuin/goldmark v1.2.1/go.mod h1:3hX8gzYuyVAZsxl0MRgGTJEmQBFcNTphYh9decYSb74= github.com/yuin/goldmark v1.3.5/go.mod h1:mwnBkeHKe2W/ZEtQ+71ViKU8L12m81fl3OWwC1Zlc8k= github.com/yuin/goldmark v1.4.13/go.mod h1:6yULJ656Px+3vBD8DxQVa3kxgyrAnzto9xy5taEt/CY= +github.com/yusufpapurcu/wmi v1.2.4 h1:zFUKzehAFReQwLys1b/iSMl+JQGSCSjtVqQn9bBrPo0= +github.com/yusufpapurcu/wmi v1.2.4/go.mod h1:SBZ9tNy3G9/m5Oi98Zks0QjeHVDvuK0qfxQmPyzfmi0= +go.opentelemetry.io/collector/component v0.104.0 h1:jqu/X9rnv8ha0RNZ1a9+x7OU49KwSMsPbOuIEykHuQE= +go.opentelemetry.io/collector/component v0.104.0/go.mod h1:1C7C0hMVSbXyY1ycCmaMUAR9fVwpgyiNQqxXtEWhVpw= +go.opentelemetry.io/collector/config/configtelemetry v0.104.0 h1:eHv98XIhapZA8MgTiipvi+FDOXoFhCYOwyKReOt+E4E= +go.opentelemetry.io/collector/config/configtelemetry v0.104.0/go.mod h1:WxWKNVAQJg/Io1nA3xLgn/DWLE/W1QOB2+/Js3ACi40= +go.opentelemetry.io/collector/pdata v1.11.0 h1:rzYyV1zfTQQz1DI9hCiaKyyaczqawN75XO9mdXmR/hE= +go.opentelemetry.io/collector/pdata v1.11.0/go.mod h1:IHxHsp+Jq/xfjORQMDJjSH6jvedOSTOyu3nbxqhWSYE= +go.opentelemetry.io/collector/semconv v0.104.0 h1:dUvajnh+AYJLEW/XOPk0T0BlwltSdi3vrjO7nSOos3k= +go.opentelemetry.io/collector/semconv v0.104.0/go.mod h1:yMVUCNoQPZVq/IPfrHrnntZTWsLf5YGZ7qwKulIl5hw= +go.opentelemetry.io/otel v1.27.0 h1:9BZoF3yMK/O1AafMiQTVu0YDj5Ea4hPhxCs7sGva+cg= +go.opentelemetry.io/otel v1.27.0/go.mod h1:DMpAK8fzYRzs+bi3rS5REupisuqTheUlSZJ1WnZaPAQ= +go.opentelemetry.io/otel/exporters/prometheus v0.49.0 h1:Er5I1g/YhfYv9Affk9nJLfH/+qCCVVg1f2R9AbJfqDQ= +go.opentelemetry.io/otel/exporters/prometheus v0.49.0/go.mod h1:KfQ1wpjf3zsHjzP149P4LyAwWRupc6c7t1ZJ9eXpKQM= +go.opentelemetry.io/otel/metric v1.27.0 h1:hvj3vdEKyeCi4YaYfNjv2NUje8FqKqUY8IlF0FxV/ik= +go.opentelemetry.io/otel/metric v1.27.0/go.mod h1:mVFgmRlhljgBiuk/MP/oKylr4hs85GZAylncepAX/ak= +go.opentelemetry.io/otel/sdk v1.27.0 h1:mlk+/Y1gLPLn84U4tI8d3GNJmGT/eXe3ZuOXN9kTWmI= +go.opentelemetry.io/otel/sdk v1.27.0/go.mod h1:Ha9vbLwJE6W86YstIywK2xFfPjbWlCuwPtMkKdz/Y4A= +go.opentelemetry.io/otel/sdk/metric v1.27.0 h1:5uGNOlpXi+Hbo/DRoI31BSb1v+OGcpv2NemcCrOL8gI= +go.opentelemetry.io/otel/sdk/metric v1.27.0/go.mod h1:we7jJVrYN2kh3mVBlswtPU22K0SA+769l93J6bsyvqw= +go.opentelemetry.io/otel/trace v1.27.0 h1:IqYb813p7cmbHk0a5y6pD5JPakbVfftRXABGt5/Rscw= +go.opentelemetry.io/otel/trace v1.27.0/go.mod h1:6RiD1hkAprV4/q+yd2ln1HG9GoPx39SuvvstaLBl+l4= go.uber.org/atomic v1.9.0/go.mod h1:fEN4uk6kAWBTFdckzkM89CLk9XfWZrxpCo0nPH17wJc= go.uber.org/atomic v1.11.0 h1:ZvwS0R+56ePWxUNi+Atn9dWONBPp/AUETXlHW0DxSjE= go.uber.org/atomic v1.11.0/go.mod h1:LUxbIzbOniOlMKjJjyPfpl4v+PKK2cNJn91OQbhoJI0= go.uber.org/goleak v1.3.0 h1:2K3zAYmnTNqV73imy9J1T3WC+gmCePx2hEGkimedGto= go.uber.org/goleak v1.3.0/go.mod h1:CoHD4mav9JJNrW/WLlf7HGZPjdw8EucARQHekz1X6bE= +go.uber.org/multierr v1.11.0 h1:blXXJkSxSSfBVBlC76pxqeO+LN3aDfLQo+309xJstO0= +go.uber.org/multierr v1.11.0/go.mod h1:20+QtiLqy0Nd6FdQB9TLXag12DsQkrbs3htMFfDN80Y= +go.uber.org/zap v1.27.0 h1:aJMhYGrd5QSmlpLMr2MftRKl7t8J8PTZPA732ud/XR8= +go.uber.org/zap v1.27.0/go.mod h1:GB2qFLM7cTU87MWRP2mPIjqfIDnGu+VIO4V/SdhGo2E= golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACkg1iLfiJU5Ep61QUkGW8qpdssI0+w= golang.org/x/crypto v0.0.0-20191011191535-87dc89f01550/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= +golang.org/x/crypto v0.0.0-20200622213623-75b288015ac9/go.mod h1:LzIPMQfyMNhhGPhUkYOs5KpL4U8rLKemX1yGLhDgUto= golang.org/x/crypto v0.0.0-20210921155107-089bfa567519/go.mod h1:GvvjBRRGRdwPK5ydBHafDWAxML/pGHZbMvKqRZ5+Abc= -golang.org/x/crypto v0.21.0 h1:X31++rzVUdKhX5sWmSOFZxx8UW/ldWx55cbf08iNAMA= -golang.org/x/crypto v0.21.0/go.mod h1:0BP7YvVV9gBbVKyeTG0Gyn+gZm94bibOW5BjDEYAOMs= +golang.org/x/crypto v0.25.0 h1:ypSNr+bnYL2YhwoMt2zPxHFmbAN1KZs/njMG3hxUp30= +golang.org/x/crypto v0.25.0/go.mod h1:T+wALwcMOSE0kXgUAnPAHqTLW+XHgcELELW8VaDgm/M= golang.org/x/exp v0.0.0-20240506185415-9bf2ced13842 h1:vr/HnozRka3pE4EsMEg1lgkXJkTFJCVUX+S/ZT6wYzM= golang.org/x/exp v0.0.0-20240506185415-9bf2ced13842/go.mod h1:XtvwrStGgqGPLc4cjQfWqZHG1YFdYs6swckp8vpsjnc= +golang.org/x/mod v0.2.0/go.mod h1:s0Qsj1ACt9ePp/hMypM3fl4fZqREWJwdYDEqhRiZZUA= +golang.org/x/mod v0.3.0/go.mod h1:s0Qsj1ACt9ePp/hMypM3fl4fZqREWJwdYDEqhRiZZUA= golang.org/x/mod v0.4.2/go.mod h1:s0Qsj1ACt9ePp/hMypM3fl4fZqREWJwdYDEqhRiZZUA= golang.org/x/mod v0.6.0-dev.0.20220419223038-86c51ed26bb4/go.mod h1:jJ57K6gSWd91VN4djpZkiMVwK6gcyfeH4XE8wZrZaV4= golang.org/x/mod v0.7.0/go.mod h1:iBbtSCu2XBx23ZKBPSOrRkjjQPZFPuis4dIYUhu/chs= -golang.org/x/mod v0.17.0 h1:zY54UmvipHiNd+pm+m0x9KhZ9hl1/7QNMyxXbc6ICqA= -golang.org/x/mod v0.17.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= +golang.org/x/mod v0.20.0 h1:utOm6MM3R3dnawAiJgn0y+xvuYRsm1RKM/4giyfDgV0= golang.org/x/mod v0.20.0/go.mod h1:hTbmBsO62+eylJbnUtE2MGJUyE7QWk4xUqPFrRgJ+7c= golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= +golang.org/x/net v0.0.0-20200226121028-0de0cce0169b/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= +golang.org/x/net v0.0.0-20201021035429-f5854403a974/go.mod h1:sp8m0HH+o8qH0wwXwYZr8TS3Oi6o0r6Gce1SSxlDquU= golang.org/x/net v0.0.0-20210226172049-e18ecbb05110/go.mod h1:m0MpNAwzfU5UDzcl9v0D8zg8gWTRqZa9RBIspLL5mdg= golang.org/x/net v0.0.0-20210405180319-a5a99cb37ef4/go.mod h1:p54w0d4576C0XHj96bSt6lcn1PtDYWL6XObtHCRCNQM= golang.org/x/net v0.0.0-20220722155237-a158d28d115b/go.mod h1:XRhObCWvk6IyKnWLug+ECip1KBveYUHfp+8e9klMJ9c= golang.org/x/net v0.3.0/go.mod h1:MBQ8lrhLObU/6UmLb4fmbmk5OcyYmqtbGd/9yIeKjEE= +golang.org/x/net v0.27.0 h1:5K3Njcw06/l2y9vpGCSdcxWOYHOUk3dVNGDXN+FvAys= +golang.org/x/net v0.27.0/go.mod h1:dDi0PyhWNoiUOrAS8uXv/vnScO4wnHQO4mj9fn/RytE= golang.org/x/sync v0.0.0-20190423024810-112230192c58/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= +golang.org/x/sync v0.0.0-20190911185100-cd5d95a43a6e/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= +golang.org/x/sync v0.0.0-20201020160332-67f06af15bc9/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20210220032951-036812b2e83c/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20220722155255-886fb9371eb4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.1.0/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= -golang.org/x/sync v0.7.0 h1:YsImfSBoP9QPYL0xyKJPq0gcaJdG3rInoqxTWbfQu9M= -golang.org/x/sync v0.7.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= +golang.org/x/sync v0.8.0 h1:3NFvSEYkUoMifnESzZl15y791HH1qU2xm6eCJU5ZPXQ= golang.org/x/sync v0.8.0/go.mod h1:Czt+wKu1gCyEFDUtn0jG5QVvpJ6rzVqr5aXyt9drQfk= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20190916202348-b4ddaad3f8a3/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20191026070338-33540a1f6037/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20200930185726-fdedc70b468f/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20201119102817-f84b799fce68/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20201204225414-ed752295db88/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210124154548-22da62e12c0c/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210330210617-4fbd30eecc44/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20210510120138-977fb7262007/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= @@ -157,8 +259,10 @@ golang.org/x/sys v0.0.0-20220520151302-bc2c85ada10a/go.mod h1:oPkhp1MJrh7nUepCBc golang.org/x/sys v0.0.0-20220627191245-f75cf1eec38b/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.0.0-20220722155257-8c9f86f7a55f/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= golang.org/x/sys v0.3.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= -golang.org/x/sys v0.20.0 h1:Od9JTbYCk261bKm4M/mw7AklTlFYIa0bIp9BgSm1S8Y= -golang.org/x/sys v0.20.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.8.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= +golang.org/x/sys v0.11.0/go.mod h1:oPkhp1MJrh7nUepCBck5+mAzfO9JrbApNNgaTdGDITg= +golang.org/x/sys v0.19.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= +golang.org/x/sys v0.23.0 h1:YfKFowiIMvtgl1UERQoTPPToxltDeZfbj4H7dVUCwmM= golang.org/x/sys v0.23.0/go.mod h1:/VUhepiaJMQUp4+oa/7Zr1D23ma6VTLIYjOOTFZPUcA= golang.org/x/term v0.0.0-20201126162022-7de9c90e9dd1/go.mod h1:bj7SfCRtBDWHUb9snDiAeCFNEtKQo2Wmx5Cou7ajbmo= golang.org/x/term v0.0.0-20210927222741-03fcf44c2211/go.mod h1:jbD1KX2456YbFQfuXm/mYQcufACuNUgVhRMnK/tPxf8= @@ -167,28 +271,40 @@ golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= golang.org/x/text v0.3.3/go.mod h1:5Zoc/QRtKVWzQhOtBMvqHzDpF6irO9z98xDceosuGiQ= golang.org/x/text v0.3.7/go.mod h1:u+2+/6zg+i71rQMx5EYifcz6MCKuco9NR6JIITiCfzQ= golang.org/x/text v0.5.0/go.mod h1:mrYo+phRRbMaCq/xk9113O4dZlRixOauAjOtrjsXDZ8= -golang.org/x/time v0.3.0 h1:rg5rLMjNzMS1RkNLzCG38eapWhnYLFYXDXj2gOlr8j4= -golang.org/x/time v0.3.0/go.mod h1:tRJNPiyCQ0inRvYxbN9jk5I+vvW/OXSQhTDSoE431IQ= +golang.org/x/text v0.16.0 h1:a94ExnEXNtEwYLGJSIUxnWoxoRz/ZcCsV63ROupILh4= +golang.org/x/text v0.16.0/go.mod h1:GhwF1Be+LQoKShO3cGOHzqOgRrGaYc9AvblQOmPVHnI= +golang.org/x/time v0.6.0 h1:eTDhh4ZXt5Qf0augr54TN6suAUudPcawVZeIAPU7D4U= golang.org/x/time v0.6.0/go.mod h1:3BpzKBy/shNhVucY/MWOyx10tF3SFh9QdLuxbVysPQM= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20191119224855-298f0cb1881e/go.mod h1:b+2E5dAYhXwXZwtnZ6UAqBI28+e2cm9otk0dWdXHAEo= +golang.org/x/tools v0.0.0-20200619180055-7c47624df98f/go.mod h1:EkVYQZoAsY45+roYkvgYkIh4xh/qjgUK9TdY2XT94GE= +golang.org/x/tools v0.0.0-20210106214847-113979e3529a/go.mod h1:emZCQorbCU4vsT4fOWvOPXz4eW1wZW4PmDk9uLelYpA= golang.org/x/tools v0.1.1/go.mod h1:o0xws9oXOQQZyjljx8fwUC0k7L1pTE6eaCbjGeHmOkk= golang.org/x/tools v0.1.12/go.mod h1:hNGJHUnrk76NpqgfD5Aqm5Crs+Hm0VOH/i9J2+nxYbc= golang.org/x/tools v0.4.0/go.mod h1:UE5sM2OK9E/d67R0ANs2xJizIymRP5gJU295PvKXxjQ= -golang.org/x/tools v0.21.0 h1:qc0xYgIbsSDt9EyWz05J5wfa7LOVW0YTLOXrqdLAWIw= -golang.org/x/tools v0.21.0/go.mod h1:aiJjzUbINMkxbQROHiO6hDPo2LHcIPhhQsa9DLh0yGk= +golang.org/x/tools v0.23.0 h1:SGsXPZ+2l4JsgaCKkx+FQ9YZ5XEtA1GZYuoDjenLjvg= golang.org/x/tools v0.23.0/go.mod h1:pnu6ufv6vQkll6szChhK3C3L/ruaIv5eBeztNG8wtsI= golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20191011141410-1b5146add898/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= +golang.org/x/xerrors v0.0.0-20191204190536-9bdfabe68543/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20200804184101-5ec99f83aff1/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 h1:+cNy6SZtPcJQH3LJVLOSmiC7MMxXNOb3PU/VUEz+EhU= golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028/go.mod h1:NDW/Ps6MPRej6fsCIbMTohpP40sJ/P/vI1MoTEGwX90= -google.golang.org/protobuf v1.33.0 h1:uNO2rsAINq/JlFpSdYEKIZ0uKD/R9cpdv0T+yoGwGmI= -google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= +google.golang.org/appengine v1.6.8 h1:IhEN5q69dyKagZPYMSdIjS2HqprW324FRQZJcGqPAsM= +google.golang.org/appengine v1.6.8/go.mod h1:1jJ3jBArFh5pcgW8gCtRJnepW8FzD1V44FJffLiz/Ds= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 h1:Q2RxlXqh1cgzzUgV261vBO2jI5R/3DD1J2pM0nI4NhU= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5/go.mod h1:EfXuqaE1J41VCDicxHzUDm+8rk+7ZdXzHV0IhO/I6s0= +google.golang.org/grpc v1.64.0 h1:KH3VH9y/MgNQg1dE7b3XfVK0GsPSIzJwdF617gUSbvY= +google.golang.org/grpc v1.64.0/go.mod h1:oxjF8E3FBnjp+/gVFYdWacaLDx9na1aqy9oovLpxQYg= +google.golang.org/protobuf v1.34.2 h1:6xV6lTsCfpGD21XK49h7MhtcApnLqkfYgPcdHftf6hg= google.golang.org/protobuf v1.34.2/go.mod h1:qYOHts0dSfpeUzUFpOMr/WGzszTmLH+DiWniOlNbLDw= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c h1:Hei/4ADfdWqJk1ZMxUNpqntNwaWcugrBjAiHlqqRiVk= gopkg.in/check.v1 v1.0.0-20201130134442-10cb98267c6c/go.mod h1:JHkPIbrfpd72SG/EVd6muEfDQjcINNoR0C8j2r3qZ4Q= +gopkg.in/ini.v1 v1.67.0 h1:Dgnx+6+nfE+IfzjUEISNeydPJh9AXNNsWbGP9KzCsOA= +gopkg.in/ini.v1 v1.67.0/go.mod h1:pNLf8WUiyNEtQjuu5G5vTm06TEv9tsIgeAvK8hOrP4k= +gopkg.in/yaml.v2 v2.4.0 h1:D8xgwECY7CYvx+Y2n4sBz93Jn9JRvxdiyyo8CTfuKaY= +gopkg.in/yaml.v2 v2.4.0/go.mod h1:RDklbk79AGWmwhnvt/jBztapEOGDOx6ZbXqjP6csGnQ= gopkg.in/yaml.v3 v3.0.0-20200313102051-9f266ea9e77c/go.mod h1:K4uyk7z7BCEPqu6E+C64Yfv1cQ7kz7rIZviUmN+EgEM= gopkg.in/yaml.v3 v3.0.1 h1:fxVm/GzAzEWqLHuvctI91KS9hhNmmWOoWu0XTYJS7CA= gopkg.in/yaml.v3 v3.0.1/go.mod h1:K4uyk7z7BCEPqu6E+C64Yfv1cQ7kz7rIZviUmN+EgEM= From b81bc9c19ef3c22c3dd5dbae8f6570df146d34b5 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 14 Aug 2024 13:38:36 -0400 Subject: [PATCH 04/19] add testEnv for tests asserting on logs, in real usage there will be an agent env --- ddtrace/tracer/spancontext_test.go | 7 ++++--- 1 file changed, 4 insertions(+), 3 deletions(-) diff --git a/ddtrace/tracer/spancontext_test.go b/ddtrace/tracer/spancontext_test.go index f1cc69d787..b4d88338bd 100644 --- a/ddtrace/tracer/spancontext_test.go +++ b/ddtrace/tracer/spancontext_test.go @@ -40,7 +40,7 @@ func TestNewSpanContextPushError(t *testing.T) { tp := new(log.RecordLogger) tp.Ignore("appsec: ", telemetry.LogPrefix) - _, _, _, stop := startTestTracer(t, WithLogger(tp), WithLambdaMode(true)) + _, _, _, stop := startTestTracer(t, WithLogger(tp), WithLambdaMode(true), WithEnv("testEnv")) defer stop() parent := newBasicSpan("test1") // 1st span in trace parent.context.trace.push(newBasicSpan("test2")) // 2nd span in trace @@ -51,6 +51,7 @@ func TestNewSpanContextPushError(t *testing.T) { child.context = newSpanContext(child, parent.context) log.Flush() + assert.Contains(t, tp.Logs()[0], "ERROR: trace buffer full (2)") } @@ -223,7 +224,7 @@ func TestSpanTracePushNoFinish(t *testing.T) { tp := new(log.RecordLogger) tp.Ignore("appsec: ", telemetry.LogPrefix) - _, _, _, stop := startTestTracer(t, WithLogger(tp), WithLambdaMode(true)) + _, _, _, stop := startTestTracer(t, WithLogger(tp), WithLambdaMode(true), WithEnv("testEnv")) defer stop() buffer := newTrace() @@ -737,7 +738,7 @@ func TestSpanContextPushFull(t *testing.T) { traceMaxSize = 2 tp := new(log.RecordLogger) tp.Ignore("appsec: ", telemetry.LogPrefix) - _, _, _, stop := startTestTracer(t, WithLogger(tp), WithLambdaMode(true)) + _, _, _, stop := startTestTracer(t, WithLogger(tp), WithLambdaMode(true), WithEnv("testEnv")) defer stop() span1 := newBasicSpan("span1") From e187e488cb3585044a5c185017308a6104f17437 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 14 Aug 2024 13:49:29 -0400 Subject: [PATCH 05/19] bump k8s client go to match k8s api version --- go.mod | 11 ++++++++--- go.sum | 15 ++++++++++----- 2 files changed, 18 insertions(+), 8 deletions(-) diff --git a/go.mod b/go.mod index b150ff251e..f4e7bb14a3 100644 --- a/go.mod +++ b/go.mod @@ -115,7 +115,7 @@ require ( gorm.io/driver/sqlserver v1.4.2 gorm.io/gorm v1.25.3 k8s.io/apimachinery v0.25.5 - k8s.io/client-go v0.23.17 + k8s.io/client-go v0.25.5 modernc.org/sqlite v1.28.0 ) @@ -130,6 +130,8 @@ require ( github.com/DataDog/go-tuf v1.1.0-0.5.2 // indirect github.com/DataDog/opentelemetry-mapping-go/pkg/otlp/attributes v0.14.0 // indirect github.com/Microsoft/go-winio v0.6.1 // indirect + github.com/PuerkitoBio/purell v1.1.1 // indirect + github.com/PuerkitoBio/urlesc v0.0.0-20170810143723-de5bf2ad4578 // indirect github.com/agnivade/levenshtein v1.1.1 // indirect github.com/andybalholm/brotli v1.0.6 // indirect github.com/armon/go-metrics v0.4.1 // indirect @@ -170,6 +172,9 @@ require ( github.com/go-logr/logr v1.4.1 // indirect github.com/go-logr/stdr v1.2.2 // indirect github.com/go-ole/go-ole v1.2.6 // indirect + github.com/go-openapi/jsonpointer v0.19.5 // indirect + github.com/go-openapi/jsonreference v0.19.5 // indirect + github.com/go-openapi/swag v0.19.14 // indirect github.com/go-pg/zerochecker v0.2.0 // indirect github.com/go-playground/locales v0.14.1 // indirect github.com/go-playground/universal-translator v0.18.1 // indirect @@ -187,7 +192,6 @@ require ( github.com/google/s2a-go v0.1.7 // indirect github.com/googleapis/enterprise-certificate-proxy v0.3.2 // indirect github.com/googleapis/gax-go/v2 v2.12.2 // indirect - github.com/googleapis/gnostic v0.5.5 // indirect github.com/gorilla/websocket v1.5.0 // indirect github.com/hailocab/go-hostpool v0.0.0-20160125115350-e80d13ce29ed // indirect github.com/hashicorp/errwrap v1.1.0 // indirect @@ -231,6 +235,7 @@ require ( github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd // indirect github.com/modern-go/reflect2 v1.0.2 // indirect github.com/montanaflynn/stats v0.6.6 // indirect + github.com/munnerz/goautoneg v0.0.0-20191010083416-a7dc8b61c822 // indirect github.com/outcaste-io/ristretto v0.2.3 // indirect github.com/pelletier/go-toml/v2 v2.0.9 // indirect github.com/philhofer/fwd v1.1.2 // indirect @@ -297,7 +302,7 @@ require ( gopkg.in/ini.v1 v1.67.0 // indirect gopkg.in/yaml.v2 v2.4.0 // indirect gopkg.in/yaml.v3 v3.0.1 // indirect - k8s.io/api v0.23.17 // indirect + k8s.io/api v0.25.5 // indirect k8s.io/klog/v2 v2.70.1 // indirect k8s.io/kube-openapi v0.0.0-20220803162953-67bda5d908f1 // indirect k8s.io/utils v0.0.0-20220728103510-ee6ede2d64ed // indirect diff --git a/go.sum b/go.sum index b27f5af6d4..9dd9eda437 100644 --- a/go.sum +++ b/go.sum @@ -689,8 +689,10 @@ github.com/NYTimes/gziphandler v1.1.1/go.mod h1:n/CVRwUEOgIxrgPvAQhUUr9oeUtvrhMo github.com/OneOfOne/xxhash v1.2.2/go.mod h1:HSdplMjZKSmBqAxg5vPj2TmRDmfkzw+cTzAElWljhcU= github.com/PuerkitoBio/goquery v1.5.1/go.mod h1:GsLWisAFVj4WgDibEWF4pvYnkVQBpKBKeU+7zCJoLcc= github.com/PuerkitoBio/purell v1.0.0/go.mod h1:c11w/QuzBsJSee3cPx9rAFu61PvFxuPbtSwDGJws/X0= +github.com/PuerkitoBio/purell v1.1.1 h1:WEQqlqaGbrPkxLJWfBwQmfEAE1Z7ONdDLqrN38tNFfI= github.com/PuerkitoBio/purell v1.1.1/go.mod h1:c11w/QuzBsJSee3cPx9rAFu61PvFxuPbtSwDGJws/X0= github.com/PuerkitoBio/urlesc v0.0.0-20160726150825-5bd2802263f2/go.mod h1:uGdkoq3SwY9Y+13GIhn11/XLaGBb4BfwItxLd5jeuXE= +github.com/PuerkitoBio/urlesc v0.0.0-20170810143723-de5bf2ad4578 h1:d+Bc7a5rLufV/sSk/8dngufqelfh6jnri85riMAaF/M= github.com/PuerkitoBio/urlesc v0.0.0-20170810143723-de5bf2ad4578/go.mod h1:uGdkoq3SwY9Y+13GIhn11/XLaGBb4BfwItxLd5jeuXE= github.com/Shopify/logrus-bugsnag v0.0.0-20171204204709-577dee27f20d/go.mod h1:HI8ITrYtUY+O+ZhtlqUnD8+KwNPOyugEhfP9fdUIaEQ= github.com/Shopify/sarama v1.38.1 h1:lqqPUPQZ7zPqYlWpTh+LQ9bhYNu2xJL6k1SJN4WVe2A= @@ -1201,16 +1203,19 @@ github.com/go-ole/go-ole v1.2.6/go.mod h1:pprOEPIfldk/42T2oK7lQ4v4JSDwmV0As9GaiU github.com/go-openapi/jsonpointer v0.0.0-20160704185906-46af16f9f7b1/go.mod h1:+35s3my2LFTysnkMfxsJBAMHj/DoqoB9knIWoYG/Vk0= github.com/go-openapi/jsonpointer v0.19.2/go.mod h1:3akKfEdA7DF1sugOqz1dVQHBcuDBPKZGEoHC/NkiQRg= github.com/go-openapi/jsonpointer v0.19.3/go.mod h1:Pl9vOtqEWErmShwVjC8pYs9cog34VGT37dQOVbmoatg= +github.com/go-openapi/jsonpointer v0.19.5 h1:gZr+CIYByUqjcgeLXnQu2gHYQC9o73G2XUeOFYEICuY= github.com/go-openapi/jsonpointer v0.19.5/go.mod h1:Pl9vOtqEWErmShwVjC8pYs9cog34VGT37dQOVbmoatg= github.com/go-openapi/jsonreference v0.0.0-20160704190145-13c6e3589ad9/go.mod h1:W3Z9FmVs9qj+KR4zFKmDPGiLdk1D9Rlm7cyMvf57TTg= github.com/go-openapi/jsonreference v0.19.2/go.mod h1:jMjeRr2HHw6nAVajTXJ4eiUwohSTlpa0o73RUL1owJc= github.com/go-openapi/jsonreference v0.19.3/go.mod h1:rjx6GuL8TTa9VaixXglHmQmIL98+wF9xc8zWvFonSJ8= +github.com/go-openapi/jsonreference v0.19.5 h1:1WJP/wi4OjB4iV8KVbH73rQaoialJrqv8gitZLxGLtM= github.com/go-openapi/jsonreference v0.19.5/go.mod h1:RdybgQwPxbL4UEjuAruzK1x3nE69AqPYEJeo/TWfEeg= github.com/go-openapi/spec v0.0.0-20160808142527-6aced65f8501/go.mod h1:J8+jY1nAiCcj+friV/PDoE1/3eeccG9LYBs0tYvLOWc= github.com/go-openapi/spec v0.19.3/go.mod h1:FpwSN1ksY1eteniUU7X0N/BgJ7a4WvBFVA8Lj9mJglo= github.com/go-openapi/swag v0.0.0-20160704191624-1d0bd113de87/go.mod h1:DXUve3Dpr1UfpPtxFw+EFuQ41HhCWZfha5jSVRG7C7I= github.com/go-openapi/swag v0.19.2/go.mod h1:POnQmlKehdgb5mhVOsnJFsivZCEZ/vjK9gh66Z9tfKk= github.com/go-openapi/swag v0.19.5/go.mod h1:POnQmlKehdgb5mhVOsnJFsivZCEZ/vjK9gh66Z9tfKk= +github.com/go-openapi/swag v0.19.14 h1:gm3vOOXfiuw5i9p5N9xJvfjvuofpyvLA9Wr6QfK5Fng= github.com/go-openapi/swag v0.19.14/go.mod h1:QYRuS/SOXUCsnplDa677K7+DxSOj6IPNl/eQntq43wQ= github.com/go-pdf/fpdf v0.5.0/go.mod h1:HzcnA+A23uwogo0tp9yU+l3V+KXhiESpt1PMayhOh5M= github.com/go-pdf/fpdf v0.6.0/go.mod h1:HzcnA+A23uwogo0tp9yU+l3V+KXhiESpt1PMayhOh5M= @@ -1404,7 +1409,6 @@ github.com/googleapis/gax-go/v2 v2.12.2 h1:mhN09QQW1jEWeMF74zGR81R30z4VJzjZsfkUh github.com/googleapis/gax-go/v2 v2.12.2/go.mod h1:61M8vcyyXR2kqKFxKrfA22jaA8JGF7Dc8App1U3H6jc= github.com/googleapis/gnostic v0.4.1/go.mod h1:LRhVm6pbyptWbWbuZ38d1eyptfvIytN3ir6b65WBswg= github.com/googleapis/gnostic v0.5.1/go.mod h1:6U4PtQXGIEt/Z3h5MAT7FNofLnw9vXk2cUuW7uA/OeU= -github.com/googleapis/gnostic v0.5.5 h1:9fHAtK0uDfpveeqqo1hkEZJcFvYXAiCN3UutL8F9xHw= github.com/googleapis/gnostic v0.5.5/go.mod h1:7+EbHbldMins07ALC74bsA81Ovc97DwqyJO1AENw9kA= github.com/googleapis/go-type-adapters v1.0.0/go.mod h1:zHW75FOG2aur7gAO2B+MLby+cLsWGBF62rFAi7WjWO4= github.com/googleapis/google-cloud-go-testing v0.0.0-20200911160855-bcd43fbb19e8/go.mod h1:dvDLG8qkwmyD9a/MJJN3XJcT3xFxOKAvTZGvuZmac9g= @@ -1764,6 +1768,7 @@ github.com/morikuni/aec v1.0.0 h1:nP9CBfwrvYnBRgY6qfDQkygYDmYwOilePFkwzv4dU8A= github.com/morikuni/aec v1.0.0/go.mod h1:BbKIizmSmc5MMPqRYbxO4ZU0S0+P200+tUnFx7PXmsc= github.com/mrunalp/fileutils v0.5.0/go.mod h1:M1WthSahJixYnrXQl/DFQuteStB1weuxD2QJNHXfbSQ= github.com/munnerz/goautoneg v0.0.0-20120707110453-a547fc61f48d/go.mod h1:+n7T8mK8HuQTcFwEeznm/DIxMOiR9yIdICNftLE1DvQ= +github.com/munnerz/goautoneg v0.0.0-20191010083416-a7dc8b61c822 h1:C3w9PqII01/Oq1c1nUAm88MOHcQC9l5mIlSMApZMrHA= github.com/munnerz/goautoneg v0.0.0-20191010083416-a7dc8b61c822/go.mod h1:+n7T8mK8HuQTcFwEeznm/DIxMOiR9yIdICNftLE1DvQ= github.com/mwitkow/go-conntrack v0.0.0-20161129095857-cc309e4a2223/go.mod h1:qRWi+5nqEBWmkhHvq77mSJWrCKwh8bxhgT7d/eI7P4U= github.com/mwitkow/go-conntrack v0.0.0-20190716064945-2f068394615f/go.mod h1:qRWi+5nqEBWmkhHvq77mSJWrCKwh8bxhgT7d/eI7P4U= @@ -3157,8 +3162,8 @@ k8s.io/api v0.20.1/go.mod h1:KqwcCVogGxQY3nBlRpwt+wpAMF/KjaCc7RpywacvqUo= k8s.io/api v0.20.4/go.mod h1:++lNL1AJMkDymriNniQsWRkMDzRaX2Y/POTUi8yvqYQ= k8s.io/api v0.20.6/go.mod h1:X9e8Qag6JV/bL5G6bU8sdVRltWKmdHsFUGS3eVndqE8= k8s.io/api v0.22.5/go.mod h1:mEhXyLaSD1qTOf40rRiKXkc+2iCem09rWLlFwhCEiAs= -k8s.io/api v0.23.17 h1:gC11V5AIsNXUUa/xd5RQo7djukvl5O1ZDQKwEYu0H7g= -k8s.io/api v0.23.17/go.mod h1:upM9VIzXUjEyLTmGGi0KnH8kdlPnvgv+fEJ3tggDHfE= +k8s.io/api v0.25.5 h1:mqyHf7aoaYMpdvO87mqpol+Qnsmo+y09S0PMIXwiZKo= +k8s.io/api v0.25.5/go.mod h1:RzplZX0Z8rV/WhSTfEvnyd91bBhBQTRWo85qBQwRmb8= k8s.io/apimachinery v0.20.1/go.mod h1:WlLqWAHZGg07AeltaI0MV5uk1Omp8xaN0JGLY6gkRpU= k8s.io/apimachinery v0.20.4/go.mod h1:WlLqWAHZGg07AeltaI0MV5uk1Omp8xaN0JGLY6gkRpU= k8s.io/apimachinery v0.20.6/go.mod h1:ejZXtW1Ra6V1O5H8xPBGz+T3+4gfkTCeExAHKU57MAc= @@ -3174,8 +3179,8 @@ k8s.io/client-go v0.20.1/go.mod h1:/zcHdt1TeWSd5HoUe6elJmHSQ6uLLgp4bIJHVEuy+/Y= k8s.io/client-go v0.20.4/go.mod h1:LiMv25ND1gLUdBeYxBIwKpkSC5IsozMMmOOeSJboP+k= k8s.io/client-go v0.20.6/go.mod h1:nNQMnOvEUEsOzRRFIIkdmYOjAZrC8bgq0ExboWSU1I0= k8s.io/client-go v0.22.5/go.mod h1:cs6yf/61q2T1SdQL5Rdcjg9J1ElXSwbjSrW2vFImM4Y= -k8s.io/client-go v0.23.17 h1:MbW05RO5sy+TFw2ds36SDdNSkJbr8DFVaaVrClSA8Vs= -k8s.io/client-go v0.23.17/go.mod h1:X5yz7nbJHS7q8977AKn8BWKgxeAXjl1sFsgstczUsCM= +k8s.io/client-go v0.25.5 h1:7QWVK0Ph4bLn0UwotPTc2FTgm8shreQXyvXnnHDd8rE= +k8s.io/client-go v0.25.5/go.mod h1:bOeoaUUdpyz3WDFGo+Xm3nOQFh2KuYXRDwrvbAPtFQA= k8s.io/code-generator v0.19.7/go.mod h1:lwEq3YnLYb/7uVXLorOJfxg+cUu2oihFhHZ0n9NIla0= k8s.io/component-base v0.20.1/go.mod h1:guxkoJnNoh8LNrbtiQOlyp2Y2XFCZQmrcg2n/DeYNLk= k8s.io/component-base v0.20.4/go.mod h1:t4p9EdiagbVCJKrQ1RsA5/V4rFQNDfRlevJajlGwgjI= From 704acc7c7675e2c9db916d2a4899aeb65ee5ebf7 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 14 Aug 2024 14:58:40 -0400 Subject: [PATCH 06/19] add some temp logs --- ddtrace/tracer/span.go | 1 + 1 file changed, 1 insertion(+) diff --git a/ddtrace/tracer/span.go b/ddtrace/tracer/span.go index 401f41ec4d..76962a9faf 100644 --- a/ddtrace/tracer/span.go +++ b/ddtrace/tracer/span.go @@ -553,6 +553,7 @@ func (s *span) finish(finishTime int64) { // todo: no need to check for shouldCompute if t.config.canComputeStats() && shouldComputeStats(s) { statSpan, shouldCalc := t.stats.newAggregableSpan(s, t.obfuscator) + log.Info("LETS COMPUTE SOME STATS: should calc %v stat span %v", shouldCalc, statSpan) if shouldCalc { // the agent supports computed stats select { From 21aa1ce1f6849c1451d3b23b7e375eaea3876636 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 14 Aug 2024 15:03:35 -0400 Subject: [PATCH 07/19] more logs --- ddtrace/tracer/span.go | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ddtrace/tracer/span.go b/ddtrace/tracer/span.go index 76962a9faf..0537c82ab3 100644 --- a/ddtrace/tracer/span.go +++ b/ddtrace/tracer/span.go @@ -553,7 +553,7 @@ func (s *span) finish(finishTime int64) { // todo: no need to check for shouldCompute if t.config.canComputeStats() && shouldComputeStats(s) { statSpan, shouldCalc := t.stats.newAggregableSpan(s, t.obfuscator) - log.Info("LETS COMPUTE SOME STATS: should calc %v stat span %v", shouldCalc, statSpan) + log.Info("LETS COMPUTE SOME STATS: should calc %v stat span %v", shouldCalc, s) if shouldCalc { // the agent supports computed stats select { From e3796bdc2f9b41212077866f3c921cf0076033e8 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Thu, 15 Aug 2024 13:41:15 -0400 Subject: [PATCH 08/19] bump to dev version of agent to fix parametric tests (temporary) --- go.mod | 6 ++++-- go.sum | 4 ++-- internal/apps/go.mod | 6 ++++-- internal/apps/go.sum | 4 ++-- internal/exectracetest/go.mod | 6 ++++-- internal/exectracetest/go.sum | 4 ++-- 6 files changed, 18 insertions(+), 12 deletions(-) diff --git a/go.mod b/go.mod index f4e7bb14a3..a90509a903 100644 --- a/go.mod +++ b/go.mod @@ -1,6 +1,8 @@ module gopkg.in/DataDog/dd-trace-go.v1 -go 1.21.0 +go 1.22.0 + +toolchain go1.22.5 require ( cloud.google.com/go/pubsub v1.36.1 @@ -9,7 +11,7 @@ require ( github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 - github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 + github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc github.com/DataDog/datadog-go/v5 v5.5.0 github.com/DataDog/go-libddwaf/v3 v3.3.0 github.com/DataDog/gostackparse v0.7.0 diff --git a/go.sum b/go.sum index 9dd9eda437..82a2473ddd 100644 --- a/go.sum +++ b/go.sum @@ -633,8 +633,8 @@ github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 h1:qq3MUh7MdkywBpjm0HRaY github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1/go.mod h1:5h7i2YkGEM4QOu4TUaYeSPZ1BeuXaseA276cCrSvCmM= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 h1:hVa76HpVox8Xt05qpLuqAngd9+1waSA5IVQqCFJ2RPQ= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= -github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 h1:iMJU0lqQvrpJ6LCLTWwbUlCWaazurhwwvWf8FKsaOs4= -github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1/go.mod h1:RdepkDr3A0tJ6G/B4MfMy1fzEYHovykN7pnXOK1vePg= +github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc h1:sHwKaBj+uScmpxoi+I6EEOHQwi5dzgsXDSIN9TFWwVk= +github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc/go.mod h1:/k/kF1uSwo1/Iz6j8Opee2203h5vl+GDmcXMA8xywBE= github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 h1:Bx5kkulMNaTgNH8/Piu0wpwOhd4BZR7Ht0SMv4zAKQg= github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1/go.mod h1:S/D5aNZadFQk6IWKghTnuiKVyD+9OfSfsm116VY+xlU= github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 h1:7IY8ST69RNo+x7Z2Y99BtsLPqFyTZWTh9LWWFYQBr3A= diff --git a/internal/apps/go.mod b/internal/apps/go.mod index 77792fee43..e882d5be3b 100644 --- a/internal/apps/go.mod +++ b/internal/apps/go.mod @@ -1,6 +1,8 @@ module github.com/DataDog/dd-trace-go/internal/apps -go 1.21.0 +go 1.22.0 + +toolchain go1.22.5 require ( golang.org/x/sync v0.8.0 @@ -10,7 +12,7 @@ require ( require ( github.com/DataDog/appsec-internal-go v1.7.0 // indirect github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 // indirect - github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc // indirect github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 // indirect github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 // indirect github.com/DataDog/go-libddwaf/v3 v3.3.0 // indirect diff --git a/internal/apps/go.sum b/internal/apps/go.sum index 4297013c28..4e9454e89c 100644 --- a/internal/apps/go.sum +++ b/internal/apps/go.sum @@ -6,8 +6,8 @@ github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 h1:qq3MUh7MdkywBpjm0HRaY github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1/go.mod h1:5h7i2YkGEM4QOu4TUaYeSPZ1BeuXaseA276cCrSvCmM= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 h1:hVa76HpVox8Xt05qpLuqAngd9+1waSA5IVQqCFJ2RPQ= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= -github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 h1:iMJU0lqQvrpJ6LCLTWwbUlCWaazurhwwvWf8FKsaOs4= -github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1/go.mod h1:RdepkDr3A0tJ6G/B4MfMy1fzEYHovykN7pnXOK1vePg= +github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc h1:sHwKaBj+uScmpxoi+I6EEOHQwi5dzgsXDSIN9TFWwVk= +github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc/go.mod h1:/k/kF1uSwo1/Iz6j8Opee2203h5vl+GDmcXMA8xywBE= github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 h1:Bx5kkulMNaTgNH8/Piu0wpwOhd4BZR7Ht0SMv4zAKQg= github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1/go.mod h1:S/D5aNZadFQk6IWKghTnuiKVyD+9OfSfsm116VY+xlU= github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 h1:7IY8ST69RNo+x7Z2Y99BtsLPqFyTZWTh9LWWFYQBr3A= diff --git a/internal/exectracetest/go.mod b/internal/exectracetest/go.mod index 4e0d754435..51512728d2 100644 --- a/internal/exectracetest/go.mod +++ b/internal/exectracetest/go.mod @@ -1,6 +1,8 @@ module gopkg.in/DataDog/dd-trace-go.v1/internal/exectracetest -go 1.21.0 +go 1.22.0 + +toolchain go1.22.5 require ( github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b @@ -14,7 +16,7 @@ require ( github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 // indirect github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 // indirect github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 // indirect - github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 // indirect + github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc // indirect github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 // indirect github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 // indirect github.com/DataDog/datadog-go/v5 v5.5.0 // indirect diff --git a/internal/exectracetest/go.sum b/internal/exectracetest/go.sum index 33c364027c..d670cc7125 100644 --- a/internal/exectracetest/go.sum +++ b/internal/exectracetest/go.sum @@ -6,8 +6,8 @@ github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1 h1:qq3MUh7MdkywBpjm0HRaY github.com/DataDog/datadog-agent/pkg/proto v0.57.0-rc.1/go.mod h1:5h7i2YkGEM4QOu4TUaYeSPZ1BeuXaseA276cCrSvCmM= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1 h1:hVa76HpVox8Xt05qpLuqAngd9+1waSA5IVQqCFJ2RPQ= github.com/DataDog/datadog-agent/pkg/remoteconfig/state v0.57.0-rc.1/go.mod h1:iEvtuoiXxM0txFyANERwumS2giXnUHO9MPHukC8YjdM= -github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1 h1:iMJU0lqQvrpJ6LCLTWwbUlCWaazurhwwvWf8FKsaOs4= -github.com/DataDog/datadog-agent/pkg/trace v0.57.0-rc.1/go.mod h1:RdepkDr3A0tJ6G/B4MfMy1fzEYHovykN7pnXOK1vePg= +github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc h1:sHwKaBj+uScmpxoi+I6EEOHQwi5dzgsXDSIN9TFWwVk= +github.com/DataDog/datadog-agent/pkg/trace v0.58.0-devel.0.20240814201000-ba7e423fc4fc/go.mod h1:/k/kF1uSwo1/Iz6j8Opee2203h5vl+GDmcXMA8xywBE= github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 h1:Bx5kkulMNaTgNH8/Piu0wpwOhd4BZR7Ht0SMv4zAKQg= github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1/go.mod h1:S/D5aNZadFQk6IWKghTnuiKVyD+9OfSfsm116VY+xlU= github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 h1:7IY8ST69RNo+x7Z2Y99BtsLPqFyTZWTh9LWWFYQBr3A= From cfe668dbd71f662bc19430506304d7aede424d1e Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Thu, 15 Aug 2024 14:03:27 -0400 Subject: [PATCH 09/19] Clone net http request to avoid race --- contrib/net/http/http_test.go | 6 ++++-- 1 file changed, 4 insertions(+), 2 deletions(-) diff --git a/contrib/net/http/http_test.go b/contrib/net/http/http_test.go index 47e0370e13..e7431514f1 100644 --- a/contrib/net/http/http_test.go +++ b/contrib/net/http/http_test.go @@ -6,6 +6,7 @@ package http import ( + "context" "net/http" "net/http/httptest" "strings" @@ -346,9 +347,10 @@ func TestWrapHandlerWithResourceNameNoRace(_ *testing.T) { for i := 0; i < 10; i++ { wg.Add(1) go func() { - w := httptest.NewRecorder() defer wg.Done() - mux.ServeHTTP(w, r) + req := r.Clone(context.Background()) + w := httptest.NewRecorder() + mux.ServeHTTP(w, req) }() } wg.Wait() From c64efa3170d64f182a8007fcf858fdcf625909cb Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Thu, 15 Aug 2024 14:25:28 -0400 Subject: [PATCH 10/19] stats need accurate origin for synthetics --- ddtrace/tracer/stats.go | 25 ++++++++++---- ddtrace/tracer/stats_test.go | 65 ++++++++++++++++++------------------ 2 files changed, 51 insertions(+), 39 deletions(-) diff --git a/ddtrace/tracer/stats.go b/ddtrace/tracer/stats.go index 259acbd3c9..149ac2d5a2 100644 --- a/ddtrace/tracer/stats.go +++ b/ddtrace/tracer/stats.go @@ -31,7 +31,7 @@ type concentrator struct { // In specifies the channel to be used for feeding data to the concentrator. // In order for In to have a consumer, the concentrator must be started using // a call to Start. - In chan *stats.StatSpan + In chan *tracerStatSpan // stopped reports whether the concentrator is stopped (when non-zero) stopped uint32 @@ -47,6 +47,11 @@ type concentrator struct { statsdClient internal.StatsdClient // statsd client for sending metrics. } +type tracerStatSpan struct { + statSpan *stats.StatSpan + origin string +} + // newConcentrator creates a new concentrator using the given tracer // configuration c. It creates buckets of bucketSize nanoseconds duration. func newConcentrator(c *config, bucketSize int64) *concentrator { @@ -75,7 +80,7 @@ func newConcentrator(c *config, bucketSize int64) *concentrator { } spanConcentrator := stats.NewSpanConcentrator(sCfg, time.Now()) return &concentrator{ - In: make(chan *stats.StatSpan, 10000), + In: make(chan *tracerStatSpan, 10000), bucketSize: bucketSize, stopped: 1, cfg: c, @@ -145,14 +150,22 @@ func (c *concentrator) runIngester() { } } -func (c *concentrator) newAggregableSpan(s *span, obfuscator *obfuscate.Obfuscator) (*stats.StatSpan, bool) { - return c.spanConcentrator.NewStatSpan(s.Service, obfuscatedResource(obfuscator, s.Type, s.Resource), +func (c *concentrator) newAggregableSpan(s *span, obfuscator *obfuscate.Obfuscator) (*tracerStatSpan, bool) { + statSpan, ok := c.spanConcentrator.NewStatSpan(s.Service, obfuscatedResource(obfuscator, s.Type, s.Resource), s.Name, s.Type, s.ParentID, s.Start, s.Duration, s.Error, s.Meta, s.Metrics, c.cfg.agent.peerTags) + if !ok { + return nil, false + } + origin := s.Meta[keyOrigin] + return &tracerStatSpan{ + statSpan: statSpan, + origin: origin, + }, true } // add adds s into the concentrator's internal stats buckets. -func (c *concentrator) add(s *stats.StatSpan) { - c.spanConcentrator.AddSpan(s, c.aggregationKey, "", nil, "") //todo: origin? +func (c *concentrator) add(s *tracerStatSpan) { + c.spanConcentrator.AddSpan(s.statSpan, c.aggregationKey, "", nil, s.origin) } // Stop stops the concentrator and blocks until the operation completes. diff --git a/ddtrace/tracer/stats_test.go b/ddtrace/tracer/stats_test.go index 5292e9230f..6af412ac50 100644 --- a/ddtrace/tracer/stats_test.go +++ b/ddtrace/tracer/stats_test.go @@ -11,9 +11,6 @@ import ( "time" "github.com/stretchr/testify/assert" - "github.com/stretchr/testify/require" - - "github.com/DataDog/datadog-agent/pkg/trace/stats" ) func TestAlignTs(t *testing.T) { @@ -25,22 +22,21 @@ func TestAlignTs(t *testing.T) { func TestConcentrator(t *testing.T) { bucketSize := int64(500_000) - - sc := stats.NewSpanConcentrator(&stats.SpanConcentratorConfig{BucketInterval: bucketSize}, time.Now()) - ss1, ok := sc.NewStatSpan("", "", "http.request", "", 0, - time.Now().UnixNano()+3*bucketSize, - 1, - 0, nil, map[string]float64{keyMeasured: 1}, nil) - require.True(t, ok) - ss2, ok := sc.NewStatSpan("", "", "sql.query", "", 0, - time.Now().UnixNano()+4*bucketSize, - 1, - 0, nil, map[string]float64{keyMeasured: 1}, nil) - require.True(t, ok) - + s1 := span{ + Name: "http.request", + Start: time.Now().UnixNano() + 3*bucketSize, + Duration: 1, + Metrics: map[string]float64{keyMeasured: 1}, + } + s2 := span{ + Name: "sql.query", + Start: time.Now().UnixNano() + 4*bucketSize, + Duration: 1, + Metrics: map[string]float64{keyMeasured: 1}, + } t.Run("start-stop", func(t *testing.T) { assert := assert.New(t) - c := newConcentrator(&config{}, defaultStatsBucketSize) + c := newConcentrator(&config{}, bucketSize) assert.EqualValues(atomic.LoadUint32(&c.stopped), 1) c.Start() assert.EqualValues(atomic.LoadUint32(&c.stopped), 0) @@ -99,6 +95,8 @@ func TestConcentrator(t *testing.T) { transport := newDummyTransport() c := newConcentrator(&config{transport: transport, env: "someEnv"}, 500_000) assert.Len(t, transport.Stats(), 0) + ss1, ok := c.newAggregableSpan(&s1, nil) + assert.True(t, ok) c.Start() c.In <- ss1 time.Sleep(2 * time.Millisecond * timeMultiplicator) @@ -114,6 +112,10 @@ func TestConcentrator(t *testing.T) { transport := newDummyTransport() c := newConcentrator(&config{transport: transport, env: "someEnv"}, (10 * time.Second).Nanoseconds()) assert.Len(t, transport.Stats(), 0) + ss1, ok := c.newAggregableSpan(&s1, nil) + assert.True(t, ok) + ss2, ok := c.newAggregableSpan(&s2, nil) + assert.True(t, ok) c.Start() c.In <- ss1 c.In <- ss2 @@ -130,21 +132,18 @@ func TestConcentrator(t *testing.T) { assert.NotNil(t, names["http.request"]) assert.NotNil(t, names["potato"]) }) + + // stats should be sent if the concentrator is stopped + t.Run("stop", func(t *testing.T) { + transport := newDummyTransport() + c := newConcentrator(&config{transport: transport}, 500000) + assert.Len(t, transport.Stats(), 0) + ss1, ok := c.newAggregableSpan(&s1, nil) + assert.True(t, ok) + c.Start() + c.In <- ss1 + c.Stop() + assert.NotEmpty(t, transport.Stats()) + }) }) - // - // // stats should be sent if the concentrator is stopped - // t.Run("stop", func(t *testing.T) { - // transport := newDummyTransport() - // c := newConcentrator(&config{transport: transport}, 500000) - // assert.Len(t, transport.Stats(), 0) - // c.Start() - // c.In <- &aggregableSpan{ - // key: key1, - // Start: time.Now().UnixNano(), - // Duration: 1, - // } - // c.Stop() - // assert.NotEmpty(t, transport.Stats()) - // }) - //}) } From 0520899cf95574e6cf5a7b22f122e5871adfad2b Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Thu, 15 Aug 2024 16:08:31 -0400 Subject: [PATCH 11/19] Bump google.golang.org/api to newer version to avoid downgrade of dd-agent The dd-agent and google.golang.org/api both rely on google.golang.org/grpc, the old version of the api package forces a downgrade of the datadog-agent which breaks the build. --- .github/workflows/unit-integration-tests.yml | 2 +- .../google.golang.org/api/gen_endpoints.json | 2 +- .../api/internal/gen_endpoints/main.go | 5 +- go.mod | 32 ++++----- go.sum | 67 ++++++++++--------- internal/apps/go.mod | 4 +- internal/apps/go.sum | 12 ++-- internal/exectracetest/go.mod | 4 +- internal/exectracetest/go.sum | 12 ++-- 9 files changed, 73 insertions(+), 67 deletions(-) diff --git a/.github/workflows/unit-integration-tests.yml b/.github/workflows/unit-integration-tests.yml index 81d027f00d..216ad2725b 100644 --- a/.github/workflows/unit-integration-tests.yml +++ b/.github/workflows/unit-integration-tests.yml @@ -242,7 +242,7 @@ jobs: - name: Testing outlier google.golang.org/api run: | - go get google.golang.org/api@v0.121.0 # version used to generate code + go get google.golang.org/api@v0.192.0 # version used to generate code go mod tidy # Go1.16 doesn't update the sum file correctly after the go get, this tidy fixes it go test -v ./contrib/google.golang.org/api/... diff --git a/contrib/google.golang.org/api/gen_endpoints.json b/contrib/google.golang.org/api/gen_endpoints.json index 8a4a6e50b4..0b68695930 100644 --- a/contrib/google.golang.org/api/gen_endpoints.json +++ b/contrib/google.golang.org/api/gen_endpoints.json @@ -1 +1 @@ -[{"hostname":"","http_method":"GET","path_template":"/_ah/api/tshealth/v1/techs/count","path_regex":"^(?:/_ah/api/tshealth/v1/techs/count)$","service_name":"google.tshealth","resource_name":"tshealth.techs.count"},{"hostname":"","http_method":"GET","path_template":"/accounts/{accountId}/reports","path_regex":"^(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.repeated","resource_name":"adsense.accounts.reports.generate"},{"hostname":"","http_method":"GET","path_template":"/map","path_regex":"^(?:/map)$","service_name":"google.additionalprops","resource_name":"mapofstrings.getMap"},{"hostname":"","http_method":"GET","path_template":"/map","path_regex":"^(?:/map)$","service_name":"google.additionalprops","resource_name":"mapofstrings.getMap"},{"hostname":"","http_method":"GET","path_template":"/reports","path_regex":"^(?:/reports)$","service_name":"google.paramrename","resource_name":"youtubeAnalytics.reports.query"},{"hostname":"","http_method":"GET","path_template":"/{project}/metricDescriptors","path_regex":"^(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors)$","service_name":"google.getwithoutbody","resource_name":"getwithoutbody.metricDescriptors.list"},{"hostname":"","http_method":"POST","path_template":"/calendars/{calendarId}/events/{eventId}/move","path_regex":"^(?:/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.paramrename","resource_name":"calendar.events.move"},{"hostname":"abusiveexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/sites/{sitesId}","path_regex":"^(?:/v1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.abusiveexperiencereport","resource_name":"abusiveexperiencereport.sites.get"},{"hostname":"abusiveexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/violatingSites","path_regex":"^(?:/v1/violatingSites)$","service_name":"google.abusiveexperiencereport","resource_name":"abusiveexperiencereport.violatingSites.list"},{"hostname":"acceleratedmobilepageurl.googleapis.com","http_method":"POST","path_template":"/v1/ampUrls:batchGet","path_regex":"^(?:/v1/ampUrls:batchGet)$","service_name":"google.acceleratedmobilepageurl","resource_name":"acceleratedmobilepageurl.ampUrls.batchGet"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/approvalRequests","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/serviceAccount","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.getServiceAccount"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/approvalRequests","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/serviceAccount","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.getServiceAccount"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/approvalRequests","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccount","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.getServiceAccount"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/approvalRequests","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/approvalRequests","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:invalidate","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::invalidate)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.invalidate"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:invalidate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::invalidate)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.invalidate"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:invalidate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::invalidate)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.invalidate"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.dismiss"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs/{authorizedOrgsDescsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings/{gcpUserAccessBindingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies","path_regex":"^(?:/v1/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs/{authorizedOrgsDescsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings/{gcpUserAccessBindingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies","path_regex":"^(?:/v1beta/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/operations/{operationsId}","path_regex":"^(?:/v1beta/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs/{authorizedOrgsDescsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings/{gcpUserAccessBindingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies","path_regex":"^(?:/v1/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}:testIamPermissions","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.testIamPermissions"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels:replaceAll","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels:replaceAll)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.replaceAll"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}:testIamPermissions","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.testIamPermissions"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters:commit","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters:commit)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.commit"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters:replaceAll","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters:replaceAll)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.replaceAll"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.getIamPolicy"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.setIamPolicy"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.testIamPermissions"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.cancel"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1beta/accessPolicies","path_regex":"^(?:/v1beta/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.create"},{"hostname":"acmedns.googleapis.com","http_method":"GET","path_template":"/v1/acmeChallengeSets/{rootDomain}","path_regex":"^(?:/v1/acmeChallengeSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.acmedns","resource_name":"acmedns.acmeChallengeSets.get"},{"hostname":"acmedns.googleapis.com","http_method":"POST","path_template":"/v1/acmeChallengeSets/{rootDomain}:rotateChallenges","path_regex":"^(?:/v1/acmeChallengeSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rotateChallenges)$","service_name":"google.acmedns","resource_name":"acmedns.acmeChallengeSets.rotateChallenges"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.delete"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.delete"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/invitations","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.invitations.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/invitations/{invitationId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.invitations.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/users","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.users.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/users/{userId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.users.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/creatives","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}/dealAssociations","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dealAssociations)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.dealAssociations.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/finalizedProposals","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedProposals)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.finalizedProposals.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/products","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.products.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/products/{productId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.products.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/proposals","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/publisherProfiles","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.publisherProfiles.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/publisherProfiles/{publisherProfileId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.publisherProfiles.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/bidMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.bidMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/bidResponseErrors","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponseErrors)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.bidResponseErrors.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/bidResponsesWithoutBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponsesWithoutBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.bidResponsesWithoutBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBidRequests","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBidRequests)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBidRequests.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/creatives","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBids.creatives.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/details","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBids.details.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/impressionMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/impressionMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.impressionMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/losingBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/losingBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.losingBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/nonBillableWinningBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nonBillableWinningBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.nonBillableWinningBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/bidMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.bidMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/bidResponseErrors","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponseErrors)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.bidResponseErrors.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/bidResponsesWithoutBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponsesWithoutBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.bidResponsesWithoutBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBidRequests","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBidRequests)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBidRequests.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/creatives","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBids.creatives.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/details","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBids.details.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/impressionMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/impressionMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.impressionMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/losingBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/losingBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.losingBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/nonBillableWinningBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nonBillableWinningBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.nonBillableWinningBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/clients","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/invitations","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.invitations.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}/dealAssociations:add","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dealAssociations:add)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.dealAssociations.add"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}/dealAssociations:remove","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dealAssociations:remove)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.dealAssociations.remove"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}:stopWatching","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopWatching)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.stopWatching"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}:watch","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::watch)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.watch"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/finalizedProposals/{proposalId}:pause","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.finalizedProposals.pause"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/finalizedProposals/{proposalId}:resume","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.finalizedProposals.resume"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:accept","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.accept"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:addNote","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addNote)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.addNote"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:cancelNegotiation","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelNegotiation)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.cancelNegotiation"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:completeSetup","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeSetup)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.completeSetup"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:pause","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.pause"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:resume","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.resume"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/bidders/{biddersId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.update"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/users/{userId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.users.update"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.update"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.update"},{"hostname":"adexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/sites/{sitesId}","path_regex":"^(?:/v1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexperiencereport","resource_name":"adexperiencereport.sites.get"},{"hostname":"adexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/violatingSites","path_regex":"^(?:/v1/violatingSites)$","service_name":"google.adexperiencereport","resource_name":"adexperiencereport.violatingSites.list"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.delete"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools/{workerpoolsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.delete"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.list"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.get"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.list"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools/{workerpoolsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.get"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.operations.get"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.patch"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools/{workerpoolsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.patch"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/instances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.create"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.create"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile/{resourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.mobiledevices.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/domainaliases/{domainAliasName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domainAliases.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/domains/{domainName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domains.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/roleassignments/{roleAssignmentId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roleAssignments.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers/{printServersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers/{printersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/groups/{groupKey}/aliases/{alias}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.aliases.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/aliases/{alias}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.aliases.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/asps/{codeId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/asps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.asps.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/tokens/{clientId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.tokens.delete"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/applications","path_regex":"^(?:/admin/datatransfer/v1/applications)$","service_name":"google.admin","resource_name":"datatransfer.applications.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/applications/{applicationId}","path_regex":"^(?:/admin/datatransfer/v1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"datatransfer.applications.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/transfers","path_regex":"^(?:/admin/datatransfer/v1/transfers)$","service_name":"google.admin","resource_name":"datatransfer.transfers.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/transfers/{dataTransferId}","path_regex":"^(?:/admin/datatransfer/v1/transfers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"datatransfer.transfers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos)$","service_name":"google.admin","resource_name":"directory.chromeosdevices.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.chromeosdevices.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}/commands/{commandId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customer.devices.chromeos.commands.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile)$","service_name":"google.admin","resource_name":"directory.mobiledevices.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile/{resourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.mobiledevices.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/orgunits","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits)$","service_name":"google.admin","resource_name":"directory.orgunits.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/schemas","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.admin","resource_name":"directory.schemas.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domainaliases","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases)$","service_name":"google.admin","resource_name":"directory.domainAliases.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domainaliases/{domainAliasName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domainAliases.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domains","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.admin","resource_name":"directory.domains.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domains/{domainName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domains.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings)$","service_name":"google.admin","resource_name":"directory.resources.buildings.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars)$","service_name":"google.admin","resource_name":"directory.resources.calendars.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/features","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features)$","service_name":"google.admin","resource_name":"directory.resources.features.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roleassignments","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments)$","service_name":"google.admin","resource_name":"directory.roleAssignments.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roleassignments/{roleAssignmentId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roleAssignments.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roles","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.admin","resource_name":"directory.roles.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roles/ALL/privileges","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/ALL/privileges)$","service_name":"google.admin","resource_name":"directory.privileges.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customerKey}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.customers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers/{printServersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers/{printersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers:listPrinterModels","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers:listPrinterModels)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.listPrinterModels"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups","path_regex":"^(?:/admin/directory/v1/groups)$","service_name":"google.admin","resource_name":"directory.groups.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/aliases","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.groups.aliases.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/hasMember/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hasMember/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.hasMember"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/members","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.admin","resource_name":"directory.members.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users","path_regex":"^(?:/admin/directory/v1/users)$","service_name":"google.admin","resource_name":"directory.users.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/aliases","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.users.aliases.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/asps","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/asps)$","service_name":"google.admin","resource_name":"directory.asps.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/asps/{codeId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/asps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.asps.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/tokens","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens)$","service_name":"google.admin","resource_name":"directory.tokens.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/tokens/{clientId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.tokens.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/verificationCodes","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verificationCodes)$","service_name":"google.admin","resource_name":"directory.verificationCodes.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/activity/users/{userKey}/applications/{applicationName}","path_regex":"^(?:/admin/reports/v1/activity/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.activities.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/usage/dates/{date}","path_regex":"^(?:/admin/reports/v1/usage/dates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.customerUsageReports.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/usage/users/{userKey}/dates/{date}","path_regex":"^(?:/admin/reports/v1/usage/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.userUsageReport.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/usage/{entityType}/{entityKey}/dates/{date}","path_regex":"^(?:/admin/reports/v1/usage/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.entityUsageReports.get"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.chromeosdevices.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customers/{customerKey}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.customers.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers/{printServersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers/{printersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.patch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/datatransfer/v1/transfers","path_regex":"^(?:/admin/datatransfer/v1/transfers)$","service_name":"google.admin","resource_name":"datatransfer.transfers.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/moveDevicesToOu","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/moveDevicesToOu)$","service_name":"google.admin","resource_name":"directory.chromeosdevices.moveDevicesToOu"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}:issueCommand","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::issueCommand)$","service_name":"google.admin","resource_name":"admin.customer.devices.chromeos.issueCommand"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{resourceId}/action","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/action)$","service_name":"google.admin","resource_name":"directory.chromeosdevices.action"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile/{resourceId}/action","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/action)$","service_name":"google.admin","resource_name":"directory.mobiledevices.action"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/orgunits","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits)$","service_name":"google.admin","resource_name":"directory.orgunits.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/schemas","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.admin","resource_name":"directory.schemas.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/domainaliases","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases)$","service_name":"google.admin","resource_name":"directory.domainAliases.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/domains","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.admin","resource_name":"directory.domains.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings)$","service_name":"google.admin","resource_name":"directory.resources.buildings.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars)$","service_name":"google.admin","resource_name":"directory.resources.calendars.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/features","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features)$","service_name":"google.admin","resource_name":"directory.resources.features.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{oldName}/rename","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rename)$","service_name":"google.admin","resource_name":"directory.resources.features.rename"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/roleassignments","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments)$","service_name":"google.admin","resource_name":"directory.roleAssignments.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/roles","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.admin","resource_name":"directory.roles.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.create"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers:batchCreatePrintServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers:batchCreatePrintServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.batchCreatePrintServers"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers:batchDeletePrintServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers:batchDeletePrintServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.batchDeletePrintServers"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.create"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers:batchCreatePrinters","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers:batchCreatePrinters)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.batchCreatePrinters"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers:batchDeletePrinters","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers:batchDeletePrinters)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.batchDeletePrinters"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/groups","path_regex":"^(?:/admin/directory/v1/groups)$","service_name":"google.admin","resource_name":"directory.groups.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/groups/{groupKey}/aliases","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.groups.aliases.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/groups/{groupKey}/members","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.admin","resource_name":"directory.members.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users","path_regex":"^(?:/admin/directory/v1/users)$","service_name":"google.admin","resource_name":"directory.users.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/watch","path_regex":"^(?:/admin/directory/v1/users/watch)$","service_name":"google.admin","resource_name":"directory.users.watch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/aliases","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.users.aliases.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/aliases/watch","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/watch)$","service_name":"google.admin","resource_name":"directory.users.aliases.watch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/makeAdmin","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/makeAdmin)$","service_name":"google.admin","resource_name":"directory.users.makeAdmin"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/signOut","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/signOut)$","service_name":"google.admin","resource_name":"directory.users.signOut"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/twoStepVerification/turnOff","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/twoStepVerification/turnOff)$","service_name":"google.admin","resource_name":"directory.twoStepVerification.turnOff"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/undelete","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/undelete)$","service_name":"google.admin","resource_name":"directory.users.undelete"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/verificationCodes/generate","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verificationCodes/generate)$","service_name":"google.admin","resource_name":"directory.verificationCodes.generate"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/verificationCodes/invalidate","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verificationCodes/invalidate)$","service_name":"google.admin","resource_name":"directory.verificationCodes.invalidate"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory_v1/channels/stop","path_regex":"^(?:/admin/directory_v1/channels/stop)$","service_name":"google.admin","resource_name":"admin.channels.stop"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/reports/v1/activity/users/{userKey}/applications/{applicationName}/watch","path_regex":"^(?:/admin/reports/v1/activity/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.admin","resource_name":"reports.activities.watch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/reports_v1/channels/stop","path_regex":"^(?:/admin/reports_v1/channels/stop)$","service_name":"google.admin","resource_name":"admin.channels.stop"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.chromeosdevices.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customers/{customerKey}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.customers.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.update"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts","path_regex":"^(?:/v1/accounts)$","service_name":"google.admob","resource_name":"admob.accounts.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admob","resource_name":"admob.accounts.get"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/adUnits","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnits)$","service_name":"google.admob","resource_name":"admob.accounts.adUnits.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/apps","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.admob","resource_name":"admob.accounts.apps.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts","path_regex":"^(?:/v1beta/accounts)$","service_name":"google.admob","resource_name":"admob.accounts.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admob","resource_name":"admob.accounts.get"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/adSources","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adSources)$","service_name":"google.admob","resource_name":"admob.accounts.adSources.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/adUnits","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnits)$","service_name":"google.admob","resource_name":"admob.accounts.adUnits.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/apps","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.admob","resource_name":"admob.accounts.apps.list"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/mediationReport:generate","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.mediationReport.generate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/networkReport:generate","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.networkReport.generate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/mediationReport:generate","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.mediationReport.generate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/networkReport:generate","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.networkReport.generate"},{"hostname":"adsense.googleapis.com","http_method":"DELETE","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.delete"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts","path_regex":"^(?:/v2/accounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adBlockingRecoveryTag","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adBlockingRecoveryTag)$","service_name":"google.adsense","resource_name":"adsense.accounts.getAdBlockingRecoveryTag"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adcode","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.getAdcode"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}/adcode","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.getAdcode"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}:listLinkedCustomChannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listLinkedCustomChannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.listLinkedCustomChannels"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}:listLinkedAdUnits","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listLinkedAdUnits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.listLinkedAdUnits"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/urlchannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.urlchannels.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/urlchannels/{urlchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.urlchannels.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/alerts","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/payments","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/payments)$","service_name":"google.adsense","resource_name":"adsense.accounts.payments.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/saved","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/{reportsId}/saved","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.getSaved"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/{reportsId}/saved:generate","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/saved:generate)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generate"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/{reportsId}/saved:generateCsv","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/saved:generateCsv)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generateCsv"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports:generate","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:generate)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generate"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports:generateCsv","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:generateCsv)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generateCsv"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/sites","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.adsense","resource_name":"adsense.accounts.sites.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/sites/{sitesId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.sites.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}:listChildAccounts","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listChildAccounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.listChildAccounts"},{"hostname":"adsense.googleapis.com","http_method":"PATCH","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.patch"},{"hostname":"adsense.googleapis.com","http_method":"PATCH","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.patch"},{"hostname":"adsense.googleapis.com","http_method":"POST","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.create"},{"hostname":"adsense.googleapis.com","http_method":"POST","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.create"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/notifications","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifications)$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.organizations.locations.notifications.list"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/notifications/{notificationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.organizations.locations.notifications.get"},{"hostname":"alertcenter.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/alerts/{alertId}","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.delete"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts","path_regex":"^(?:/v1beta1/alerts)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.list"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts/{alertId}","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.get"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts/{alertId}/feedback","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedback)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.feedback.list"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts/{alertId}/metadata","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.getMetadata"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/settings","path_regex":"^(?:/v1beta1/settings)$","service_name":"google.alertcenter","resource_name":"alertcenter.getSettings"},{"hostname":"alertcenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/settings","path_regex":"^(?:/v1beta1/settings)$","service_name":"google.alertcenter","resource_name":"alertcenter.updateSettings"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts/{alertId}/feedback","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedback)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.feedback.create"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts/{alertId}:undelete","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.undelete"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts:batchDelete","path_regex":"^(?:/v1beta1/alerts:batchDelete)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.batchDelete"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts:batchUndelete","path_regex":"^(?:/v1beta1/alerts:batchUndelete)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.batchUndelete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports/{unsampledReportId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.delete"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/data/ga","path_regex":"^(?:/analytics/v3/data/ga)$","service_name":"google.analytics","resource_name":"analytics.data.ga.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/data/mcf","path_regex":"^(?:/analytics/v3/data/mcf)$","service_name":"google.analytics","resource_name":"analytics.data.mcf.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/data/realtime","path_regex":"^(?:/analytics/v3/data/realtime)$","service_name":"google.analytics","resource_name":"analytics.data.realtime.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accountSummaries","path_regex":"^(?:/analytics/v3/management/accountSummaries)$","service_name":"google.analytics","resource_name":"analytics.management.accountSummaries.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts","path_regex":"^(?:/analytics/v3/management/accounts)$","service_name":"google.analytics","resource_name":"analytics.management.accounts.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/filters","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters)$","service_name":"google.analytics","resource_name":"analytics.management.filters.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties)$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources)$","service_name":"google.analytics","resource_name":"analytics.management.customDataSources.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/uploads","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uploads)$","service_name":"google.analytics","resource_name":"analytics.management.uploads.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/uploads/{uploadId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uploads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.uploads.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions/{customDimensionId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics/{customMetricId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.analytics","resource_name":"analytics.management.profiles.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.analytics","resource_name":"analytics.management.experiments.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals)$","service_name":"google.analytics","resource_name":"analytics.management.goals.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals/{goalId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.goals.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports)$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports/{unsampledReportId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences)$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/segments","path_regex":"^(?:/analytics/v3/management/segments)$","service_name":"google.analytics","resource_name":"analytics.management.segments.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/metadata/{reportType}/columns","path_regex":"^(?:/analytics/v3/metadata/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.analytics","resource_name":"analytics.metadata.columns.list"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions/{customDimensionId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics/{customMetricId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals/{goalId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.goals.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.patch"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/filters","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters)$","service_name":"google.analytics","resource_name":"analytics.management.filters.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties)$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/deleteUploadData","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteUploadData)$","service_name":"google.analytics","resource_name":"analytics.management.uploads.deleteUploadData"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/uploads","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uploads)$","service_name":"google.analytics","resource_name":"analytics.management.uploads.uploadData"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.analytics","resource_name":"analytics.management.profiles.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.analytics","resource_name":"analytics.management.experiments.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals)$","service_name":"google.analytics","resource_name":"analytics.management.goals.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports)$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences)$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/clientId:hashClientId","path_regex":"^(?:/analytics/v3/management/clientId:hashClientId)$","service_name":"google.analytics","resource_name":"analytics.management.clientId.hashClientId"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/provisioning/createAccountTicket","path_regex":"^(?:/analytics/v3/provisioning/createAccountTicket)$","service_name":"google.analytics","resource_name":"analytics.provisioning.createAccountTicket"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/provisioning/createAccountTree","path_regex":"^(?:/analytics/v3/provisioning/createAccountTree)$","service_name":"google.analytics","resource_name":"analytics.provisioning.createAccountTree"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/userDeletion/userDeletionRequests:upsert","path_regex":"^(?:/analytics/v3/userDeletion/userDeletionRequests:upsert)$","service_name":"google.analytics","resource_name":"analytics.userDeletion.userDeletionRequest.upsert"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions/{customDimensionId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics/{customMetricId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals/{goalId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.goals.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.update"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/accounts/{accountsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/accounts/{accountsId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/accounts/{accountsId}/userLinks/{userLinksId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/channelGroups/{channelGroupsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks/{displayVideo360AdvertiserLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets/{expandedDataSetsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/firebaseLinks/{firebaseLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links/{searchAds360LinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/userLinks/{userLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/firebaseLinks/{firebaseLinksId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accountSummaries","path_regex":"^(?:/v1alpha/accountSummaries)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accountSummaries.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts","path_regex":"^(?:/v1alpha/accounts)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/accessBindings","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchGet","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchGet)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchGet"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/dataSharingSettings","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSharingSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.getDataSharingSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/userLinks","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/userLinks/{userLinksId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/userLinks:batchGet","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchGet)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.batchGet"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties","path_regex":"^(?:/v1alpha/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/accessBindings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchGet","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchGet)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchGet"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/attributionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getAttributionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/audiences","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/audiences/{audiencesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/bigQueryLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.bigQueryLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/bigQueryLinks/{bigQueryLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.bigQueryLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/channelGroups","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/channelGroups/{channelGroupsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/enhancedMeasurementSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enhancedMeasurementSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.getEnhancedMeasurementSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/globalSiteTag","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/globalSiteTag)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.getGlobalSiteTag"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks/{displayVideo360AdvertiserLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets/{expandedDataSetsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/googleSignalsSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleSignalsSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getGoogleSignalsSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links/{searchAds360LinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/userLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/userLinks/{userLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/userLinks:batchGet","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchGet)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.batchGet"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties:fetchConnectedGa4Property","path_regex":"^(?:/v1alpha/properties:fetchConnectedGa4Property)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.fetchConnectedGa4Property"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accountSummaries","path_regex":"^(?:/v1beta/accountSummaries)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accountSummaries.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts","path_regex":"^(?:/v1beta/accounts)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/dataSharingSettings","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSharingSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.getDataSharingSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties","path_regex":"^(?:/v1beta/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/accounts/{accountsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/accounts/{accountsId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/accounts/{accountsId}/userLinks/{userLinksId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/attributionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateAttributionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/audiences/{audiencesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/channelGroups/{channelGroupsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/enhancedMeasurementSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enhancedMeasurementSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.updateEnhancedMeasurementSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks/{displayVideo360AdvertiserLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets/{expandedDataSetsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/googleSignalsSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleSignalsSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateGoogleSignalsSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links/{searchAds360LinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/userLinks/{userLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchCreate","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchCreate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchCreate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchDelete","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchDelete)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchDelete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchUpdate","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchUpdate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchUpdate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/userLinks","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/userLinks:audit","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:audit)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.audit"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/userLinks:batchCreate","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchCreate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.batchCreate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/userLinks:batchDelete","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchDelete)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.batchDelete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/userLinks:batchUpdate","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchUpdate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.userLinks.batchUpdate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}:runAccessReport","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.runAccessReport"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}:searchChangeHistoryEvents","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchChangeHistoryEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.searchChangeHistoryEvents"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts:provisionAccountTicket","path_regex":"^(?:/v1alpha/accounts:provisionAccountTicket)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.provisionAccountTicket"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties","path_regex":"^(?:/v1alpha/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchCreate","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchCreate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchCreate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchDelete","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchDelete)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchDelete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchUpdate","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchUpdate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchUpdate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/audiences","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/audiences/{audiencesId}:archive","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/channelGroups","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customDimensions/{customDimensionsId}:archive","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customMetrics/{customMetricsId}:archive","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}:approve","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.approve"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}:cancel","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.cancel"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/userLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/userLinks:audit","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:audit)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.audit"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/userLinks:batchCreate","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchCreate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.batchCreate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/userLinks:batchDelete","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchDelete)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.batchDelete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/userLinks:batchUpdate","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLinks:batchUpdate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.userLinks.batchUpdate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}:acknowledgeUserDataCollection","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledgeUserDataCollection)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.acknowledgeUserDataCollection"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}:runAccessReport","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.runAccessReport"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:createConnectedSiteTag","path_regex":"^(?:/v1alpha/properties:createConnectedSiteTag)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.createConnectedSiteTag"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:deleteConnectedSiteTag","path_regex":"^(?:/v1alpha/properties:deleteConnectedSiteTag)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.deleteConnectedSiteTag"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:fetchAutomatedGa4ConfigurationOptOut","path_regex":"^(?:/v1alpha/properties:fetchAutomatedGa4ConfigurationOptOut)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.fetchAutomatedGa4ConfigurationOptOut"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:listConnectedSiteTags","path_regex":"^(?:/v1alpha/properties:listConnectedSiteTags)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.listConnectedSiteTags"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:setAutomatedGa4ConfigurationOptOut","path_regex":"^(?:/v1alpha/properties:setAutomatedGa4ConfigurationOptOut)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.setAutomatedGa4ConfigurationOptOut"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}:runAccessReport","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.runAccessReport"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}:searchChangeHistoryEvents","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchChangeHistoryEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.searchChangeHistoryEvents"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts:provisionAccountTicket","path_regex":"^(?:/v1beta/accounts:provisionAccountTicket)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.provisionAccountTicket"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties","path_regex":"^(?:/v1beta/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customDimensions/{customDimensionsId}:archive","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customMetrics/{customMetricsId}:archive","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:acknowledgeUserDataCollection","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledgeUserDataCollection)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.acknowledgeUserDataCollection"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runAccessReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.runAccessReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/metadata","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.getMetadata"},{"hostname":"analyticsdata.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/metadata","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.getMetadata"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}:runRealtimeReport","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runRealtimeReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runRealtimeReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:batchRunPivotReports","path_regex":"^(?:/v1alpha:batchRunPivotReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.batchRunPivotReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:batchRunReports","path_regex":"^(?:/v1alpha:batchRunReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.batchRunReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:runPivotReport","path_regex":"^(?:/v1alpha:runPivotReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.runPivotReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:runReport","path_regex":"^(?:/v1alpha:runReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.runReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:batchRunPivotReports","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchRunPivotReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.batchRunPivotReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:batchRunReports","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchRunReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.batchRunReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:checkCompatibility","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkCompatibility)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.checkCompatibility"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runPivotReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runPivotReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runPivotReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runRealtimeReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runRealtimeReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runRealtimeReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runReport"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.organizations.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.get"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.get"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.organizations.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.get"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.get"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:subscribe","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.subscribe"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.testIamPermissions"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.testIamPermissions"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:subscribe","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.subscribe"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.testIamPermissions"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.testIamPermissions"},{"hostname":"analyticsreporting.googleapis.com","http_method":"POST","path_template":"/v4/reports:batchGet","path_regex":"^(?:/v4/reports:batchGet)$","service_name":"google.analyticsreporting","resource_name":"analyticsreporting.reports.batchGet"},{"hostname":"analyticsreporting.googleapis.com","http_method":"POST","path_template":"/v4/userActivity:search","path_regex":"^(?:/v4/userActivity:search)$","service_name":"google.analyticsreporting","resource_name":"analyticsreporting.userActivity.search"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"DELETE","path_template":"/v1/customers/{customersId}/configurations/{configurationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.delete"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers","path_regex":"^(?:/v1/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/configurations","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/configurations/{configurationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/devices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/dpcs","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dpcs)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.dpcs.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.operations.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/customers","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.customers.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/devices/{devicesId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/vendors","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vendors)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.vendors.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/vendors/{vendorsId}/customers","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vendors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.vendors.customers.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"PATCH","path_template":"/v1/customers/{customersId}/configurations/{configurationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.patch"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/configurations","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.create"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/devices:applyConfiguration","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:applyConfiguration)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.applyConfiguration"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/devices:removeConfiguration","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:removeConfiguration)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.removeConfiguration"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/devices:unclaim","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:unclaim)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.unclaim"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/customers","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.customers.create"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices/{devicesId}/metadata","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.metadata"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:claim","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:claim)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.claim"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:claimAsync","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:claimAsync)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.claimAsync"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:findByIdentifier","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:findByIdentifier)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.findByIdentifier"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:findByOwner","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:findByOwner)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.findByOwner"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:unclaim","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:unclaim)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.unclaim"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:unclaimAsync","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:unclaimAsync)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.unclaimAsync"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:updateMetadataAsync","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:updateMetadataAsync)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.updateMetadataAsync"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccountKeys/{keyId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccountKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.serviceaccountkeys.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters/{clusterId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/deviceAccess","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceAccess)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.revokeDeviceAccess"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs/{installId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice/{managedConfigurationForDeviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements/{entitlementId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser/{managedConfigurationForUserId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps/{webAppId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises","path_regex":"^(?:/androidenterprise/v1/enterprises)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/groupLicenses","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupLicenses)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.grouplicenses.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/groupLicenses/{groupLicenseId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupLicenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.grouplicenses.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/groupLicenses/{groupLicenseId}/users","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupLicenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.grouplicenseusers.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/appRestrictionsSchema","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appRestrictionsSchema)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.getAppRestrictionsSchema"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/managedConfigurationsSettings","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsSettings)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationssettings.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/permissions","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.getPermissions"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccount","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.getServiceAccount"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccountKeys","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccountKeys)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.serviceaccountkeys.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.getStoreLayout"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters/{clusterId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/availableProductSet","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/availableProductSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.getAvailableProductSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs/{installId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice/{managedConfigurationForDeviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/state","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/state)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.getState"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements/{entitlementId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser/{managedConfigurationForUserId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps/{webAppId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/permissions/{permissionId}","path_regex":"^(?:/androidenterprise/v1/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.permissions.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/acknowledgeNotificationSet","path_regex":"^(?:/androidenterprise/v1/enterprises/acknowledgeNotificationSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.acknowledgeNotificationSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/completeSignup","path_regex":"^(?:/androidenterprise/v1/enterprises/completeSignup)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.completeSignup"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/enroll","path_regex":"^(?:/androidenterprise/v1/enterprises/enroll)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.enroll"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/pullNotificationSet","path_regex":"^(?:/androidenterprise/v1/enterprises/pullNotificationSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.pullNotificationSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/signupUrl","path_regex":"^(?:/androidenterprise/v1/enterprises/signupUrl)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.generateSignupUrl"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/createEnrollmentToken","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEnrollmentToken)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.createEnrollmentToken"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/createWebToken","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createWebToken)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.createWebToken"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/approve","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approve)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.approve"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/generateApprovalUrl","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generateApprovalUrl)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.generateApprovalUrl"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/unapprove","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unapprove)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.unapprove"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/sendTestPushNotification","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendTestPushNotification)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.sendTestPushNotification"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccountKeys","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccountKeys)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.serviceaccountkeys.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/unenroll","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unenroll)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.unenroll"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/authenticationToken","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authenticationToken)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.generateAuthenticationToken"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/forceReportUpload","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forceReportUpload)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.forceReportUpload"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/account","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/account)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.setAccount"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.setStoreLayout"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters/{clusterId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/availableProductSet","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/availableProductSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.setAvailableProductSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs/{installId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice/{managedConfigurationForDeviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/state","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/state)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.setState"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements/{entitlementId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser/{managedConfigurationForUserId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps/{webAppId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.update"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}/operations/{operationsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.operations.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens/{enrollmentTokensId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/policies/{policiesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/webApps/{webAppsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises","path_regex":"^(?:/v1/enterprises)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/applications/{applicationsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.applications.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}/operations","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.operations.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}/operations/{operationsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.operations.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens/{enrollmentTokensId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/policies","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/policies/{policiesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/webApps","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/webApps/{webAppsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}/policies/{policiesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}/webApps/{webAppsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises","path_regex":"^(?:/v1/enterprises)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.operations.cancel"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}:issueCommand","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::issueCommand)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.issueCommand"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/webApps","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/webTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webTokens.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/signupUrls","path_regex":"^(?:/v1/signupUrls)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.signupUrls.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.deleteall"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.deleteall"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}/{imageId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}/grants/{grantsId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.grants.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{applicationsId}/externalTransactions/{externalTransactionsId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalTransactions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.externaltransactions.getexternaltransaction"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/deviceTierConfigs","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceTierConfigs)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.applications.deviceTierConfigs.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/deviceTierConfigs/{deviceTierConfigId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceTierConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.applications.deviceTierConfigs.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.apks.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/bundles","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bundles)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.bundles.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/countryAvailability/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countryAvailability/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.countryavailability.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/details","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.details.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/testers/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.testers.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/generatedApks/{versionCode}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generatedApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.generatedapks.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/generatedApks/{versionCode}/downloads/{downloadId}:download","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generatedApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/downloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.generatedapks.download"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/products/{productId}/tokens/{token}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptionsv2/tokens/{token}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptionsv2/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptionsv2.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/voidedpurchases","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/voidedpurchases)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.voidedpurchases.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/reviews","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reviews)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.reviews.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/reviews/{reviewId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.reviews.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants/{variantId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants/{variantId}:download","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.download"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/developers/{developersId}/users","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/details","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.details.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/testers/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.testers.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}/grants/{grantsId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.grants.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/internalappsharing/{packageName}/artifacts/apk","path_regex":"^(?:/androidpublisher/v3/applications/internalappsharing/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/apk)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.internalappsharingartifacts.uploadapk"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/internalappsharing/{packageName}/artifacts/bundle","path_regex":"^(?:/androidpublisher/v3/applications/internalappsharing/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/bundle)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.internalappsharingartifacts.uploadbundle"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{applicationsId}/externalTransactions","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalTransactions)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.externaltransactions.createexternaltransaction"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{applicationsId}/externalTransactions/{externalTransactionsId}:refund","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalTransactions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refund)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.externaltransactions.refundexternaltransaction"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/deviceTierConfigs","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceTierConfigs)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.applications.deviceTierConfigs.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.insert"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.apks.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/externallyHosted","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/externallyHosted)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.apks.addexternallyhosted"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/deobfuscationFiles/{deobfuscationFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deobfuscationFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.deobfuscationfiles.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/bundles","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bundles)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.bundles.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}:commit","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.commit"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}:validate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.validate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.insert"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/orders/{orderId}:refund","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refund)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.orders.refund"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/pricing:convertRegionPrices","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pricing:convertRegionPrices)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.convertRegionPrices"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/products/{productId}/tokens/{token}:acknowledge","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.acknowledge"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/products/{productId}/tokens/{token}:consume","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::consume)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.consume"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:acknowledge","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.acknowledge"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:cancel","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.cancel"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:defer","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::defer)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.defer"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:refund","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refund)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.refund"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:revoke","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.revoke"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/reviews/{reviewId}:reply","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reply)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.reviews.reply"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}:activate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.activate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}:deactivate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.deactivate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}:activate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.activate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}:deactivate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.deactivate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}:migratePrices","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::migratePrices)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.migratePrices"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}:archive","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.archive"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/developers/{developersId}/users","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}/grants","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grants)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.grants.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/details","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.details.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/testers/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.testers.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.update"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.patch"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/analytics/datastores/{datastoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans/{rateplansId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/datacollectors/{datacollectorsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.apiproducts.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/endpointAttachments/{endpointAttachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions/{debugsessionsId}/data","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.deleteData"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.undeploy"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/caches/{cachesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.caches.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/flowhooks/{flowhooksId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flowhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.flowhooks.detachSharedFlowFromFlowHook"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references/{referencesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}/{name}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.revisions.undeploy"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers/{targetserversId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides/{overridesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses/{natAddressesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/reports/{reportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.environments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories/{apicategoriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.delete"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/hybrid/issuers","path_regex":"^(?:/v1/hybrid/issuers)$","service_name":"google.apigee","resource_name":"apigee.hybrid.issuers.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations","path_regex":"^(?:/v1/organizations)$","service_name":"google.apigee","resource_name":"apigee.organizations.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/analytics/datastores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores)$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/analytics/datastores/{datastoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans/{rateplansId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.apps.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apps.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/datacollectors","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors)$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/datacollectors/{datacollectorsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/deployedIngressConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployedIngressConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.getDeployedIngressConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/balance","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/balance)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.getBalance"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/monetizationConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monetizationConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.getMonetizationConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/endpointAttachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/endpointAttachments/{endpointAttachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/deployedIngressConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployedIngressConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.getDeployedIngressConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/admin/schemav2","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/admin/schemav2)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.admin.getSchemav2"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/exports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/exports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.exports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/exports/{exportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/exports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.exports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apiSecurityRuntimeConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiSecurityRuntimeConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getApiSecurityRuntimeConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions/{debugsessionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions/{debugsessionsId}/data/{dataId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.data.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.getDeployments"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/debugmask","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugmask)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getDebugmask"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/deployedConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployedConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getDeployedConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/flowhooks/{flowhooksId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flowhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.flowhooks.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}/certificate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificate)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.getCertificate"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}/csr","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csr)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.csr"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/optimizedStats/{optimizedStatsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/optimizedStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.optimizedStats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries/{queriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries/{queriesId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries/{queriesId}/resulturl","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resulturl)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.getResulturl"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references/{referencesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.listEnvironmentResources"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}/{name}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityIncidents","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityIncidents)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityIncidents.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityIncidents/{securityIncidentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityIncidents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityIncidents.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports/{securityReportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports/{securityReportsId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports/{securityReportsId}/resultView","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resultView)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.getResultView"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.revisions.getDeployments"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/stats/{statsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.stats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers/{targetserversId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getTraceConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides/{overridesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getIamPolicy"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries/{hostQueriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries/{hostQueriesId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries/{hostQueriesId}/resultView","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resultView)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.getResultView"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports/{hostSecurityReportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports/{hostSecurityReportsId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports/{hostSecurityReportsId}/resultView","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resultView)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.getResultView"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostStats/{hostStatsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.hostStats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/canaryevaluations/{canaryevaluationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/canaryevaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.canaryevaluations.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses/{natAddressesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigee","resource_name":"apigee.organizations.operations.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.operations.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/optimizedHostStats/{optimizedHostStatsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/optimizedHostStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.optimizedHostStats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/reports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/reports/{reportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/runtimeConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.getRuntimeConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityProfiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}:listRevisions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.listRevisions"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories/{apicategoriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}:getProjectMapping","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getProjectMapping)$","service_name":"google.apigee","resource_name":"apigee.organizations.getProjectMapping"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/datacollectors/{datacollectorsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.modifyEnvironment"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/debugmask","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugmask)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.updateDebugmask"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.updateTraceConfig"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides/{overridesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories/{apicategoriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.patch"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations","path_regex":"^(?:/v1/organizations)$","service_name":"google.apigee","resource_name":"apigee.organizations.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/analytics/datastores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores)$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/analytics/datastores:test","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores:test)$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.test"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.updateApiProductAttribute"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.updateApiProxyRevision"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/datacollectors","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors)$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.setDeveloperStatus"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.generateKeyPairOrUpdateDeveloperAppStatus"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.updateDeveloperAppAttribute"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/create","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/create)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.create.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.updateDeveloperAppKey"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.apiproducts.updateDeveloperAppKeyApiProduct"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.updateDeveloperAttribute"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/balance:adjust","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/balance:adjust)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.balance.adjust"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/balance:credit","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/balance:credit)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.balance.credit"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions/{subscriptionsId}:expire","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::expire)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.expire"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/endpointAttachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/envgroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.updateEnvironment"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/exports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/exports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.exports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.deploy"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments:generateDeployChangeReport","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments:generateDeployChangeReport)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.deployments.generateDeployChangeReport"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments:generateUndeployChangeReport","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments:generateUndeployChangeReport)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.deployments.generateUndeployChangeReport"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}:generateDownloadUrl","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.generateDownloadUrl"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments:generateUploadUrl","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments:generateUploadUrl)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.generateUploadUrl"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityStats:queryTabularStats","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityStats:queryTabularStats)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityStats.queryTabularStats"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityStats:queryTimeSeriesStats","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityStats:queryTimeSeriesStats)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityStats.queryTimeSeriesStats"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.revisions.deploy"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.setIamPolicy"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:subscribe","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.subscribe"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.testIamPermissions"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:unsubscribe","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribe)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.unsubscribe"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/hostQueries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/canaryevaluations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/canaryevaluations)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.canaryevaluations.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses/{natAddressesId}:activate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.activate"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}:reportStatus","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.reportStatus"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps)$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/reports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}/environments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.environments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}/environments/{environmentsId}:computeEnvironmentScores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeEnvironmentScores)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.environments.computeEnvironmentScores"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sharedflows","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.updateSharedFlowRevision"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getSyncAuthorization","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getSyncAuthorization)$","service_name":"google.apigee","resource_name":"apigee.organizations.getSyncAuthorization"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setAddons","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAddons)$","service_name":"google.apigee","resource_name":"apigee.organizations.setAddons"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setSyncAuthorization","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSyncAuthorization)$","service_name":"google.apigee","resource_name":"apigee.organizations.setSyncAuthorization"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:provisionOrganization","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::provisionOrganization)$","service_name":"google.apigee","resource_name":"apigee.projects.provisionOrganization"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/analytics/datastores/{datastoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans/{rateplansId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.replaceDeveloperAppKey"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/monetizationConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monetizationConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.updateMonetizationConfig"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/flowhooks/{flowhooksId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flowhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.flowhooks.attachSharedFlowToFlowHook"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references/{referencesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}/{name}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers/{targetserversId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/reports/{reportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.update"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.deleteRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.deleteRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.listRevisions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.listRevisions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtime:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtime:getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.runtime.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.rollback"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:tagRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tagRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.tagRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.rollback"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:tagRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tagRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.tagRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.cancel"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtime:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtime:setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.runtime.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtime:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtime:testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.runtime.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.replaceArtifact"},{"hostname":"apikeys.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.delete"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/keys:lookupKey","path_regex":"^(?:/v2/keys:lookupKey)$","service_name":"google.apikeys","resource_name":"apikeys.keys.lookupKey"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/operations/{operationsId}","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.operations.get"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.list"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.get"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}/keyString","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyString)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.getKeyString"},{"hostname":"apikeys.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.patch"},{"hostname":"apikeys.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.create"},{"hostname":"apikeys.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}:undelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.undelete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/authorizedDomains","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/domainMappings","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/authorizedDomains","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/domainMappings","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/locations","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/operations","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/authorizedDomains","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/domainMappings","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/locations","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/operations","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/locations","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/operations","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/locations","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/operations","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta4/apps/{appsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta5/apps/{appsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps","path_regex":"^(?:/v1/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/domainMappings","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/firewall/ingressRules:batchUpdate","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules:batchUpdate)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.batchUpdate"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}:repair","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.appengine","resource_name":"appengine.apps.repair"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}:repair","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.appengine","resource_name":"appengine.apps.repair"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/apps/{appsId}/domainMappings","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps","path_regex":"^(?:/v1beta/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/domainMappings","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules:batchUpdate","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules:batchUpdate)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.batchUpdate"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}:repair","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.appengine","resource_name":"appengine.apps.repair"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/applications","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:repair","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.repair"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta4/apps","path_regex":"^(?:/v1beta4/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta5/apps","path_regex":"^(?:/v1beta5/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"area120tables.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/tables/{tablesId}/rows/{rowsId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.delete"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables","path_regex":"^(?:/v1alpha1/tables)$","service_name":"google.area120tables","resource_name":"area120tables.tables.list"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables/{tablesId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.get"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables/{tablesId}/rows","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.list"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables/{tablesId}/rows/{rowsId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.get"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/workspaces","path_regex":"^(?:/v1alpha1/workspaces)$","service_name":"google.area120tables","resource_name":"area120tables.workspaces.list"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/workspaces/{workspacesId}","path_regex":"^(?:/v1alpha1/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.workspaces.get"},{"hostname":"area120tables.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/tables/{tablesId}/rows/{rowsId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.patch"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.create"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows:batchCreate","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows:batchCreate)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.batchCreate"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows:batchDelete","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows:batchDelete)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.batchDelete"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows:batchUpdate","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows:batchUpdate)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.batchUpdate"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.operations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/dockerImages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dockerImages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.dockerImages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/dockerImages/{dockerImagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dockerImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.dockerImages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/mavenArtifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mavenArtifacts)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.mavenArtifacts.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/mavenArtifacts/{mavenArtifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mavenArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.mavenArtifacts.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/npmPackages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/npmPackages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.npmPackages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/npmPackages/{npmPackagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/npmPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.npmPackages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/pythonPackages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pythonPackages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.pythonPackages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/pythonPackages/{pythonPackagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pythonPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.pythonPackages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.getIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vpcscConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpcscConfig)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.getVpcscConfig"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.getProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.operations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.getIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.operations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.getIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.getProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vpcscConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpcscConfig)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.updateVpcscConfig"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.updateProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.updateProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/kfpArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/kfpArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.kfpArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.setIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.testIamPermissions"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.setIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.testIamPermissions"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:create","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:import","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:create","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:import","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.setIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.testIamPermissions"},{"hostname":"assuredworkloads.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.delete"},{"hostname":"assuredworkloads.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.delete"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/organizations/{organizationsId1}/locations/{locationsId1}/workloads/{workloadsId1}:analyzeWorkloadMove","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeWorkloadMove)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.organizations.locations.workloads.analyzeWorkloadMove"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:analyzeWorkloadMove","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeWorkloadMove)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.projects.organizations.locations.workloads.analyzeWorkloadMove"},{"hostname":"assuredworkloads.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.patch"},{"hostname":"assuredworkloads.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:mutatePartnerPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mutatePartnerPermissions)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.mutatePartnerPermissions"},{"hostname":"assuredworkloads.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.patch"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.create"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}:acknowledge","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.acknowledge"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:restrictAllowedResources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restrictAllowedResources)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.restrictAllowedResources"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.create"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}:acknowledge","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.acknowledge"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:restrictAllowedResources","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restrictAllowedResources)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.restrictAllowedResources"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"DELETE","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.delete"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/finalizedDeals","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.bidders.finalizedDeals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/auctionPackages","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/finalizedDeals","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals/{dealsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/publisherProfiles","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.publisherProfiles.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/publisherProfiles/{publisherProfilesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.publisherProfiles.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals/{dealsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:subscribe","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.subscribe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:subscribeClients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribeClients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.subscribeClients"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:unsubscribe","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.unsubscribe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:unsubscribeClients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribeClients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.unsubscribeClients"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.create"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.create"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}:activate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.activate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}:deactivate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.deactivate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}:activate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.activate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}:deactivate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.deactivate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:addCreative","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addCreative)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.addCreative"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:pause","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.pause"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:resume","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.resume"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:setReadyToServe","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setReadyToServe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.setReadyToServe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals:batchUpdate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals:batchUpdate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.batchUpdate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}:accept","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.accept"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}:addNote","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addNote)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.addNote"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}:cancelNegotiation","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelNegotiation)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.cancelNegotiation"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals:sendRfp","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals:sendRfp)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.sendRfp"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/sshKeys/{sshKeysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.sshKeys.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/provisioningQuotas","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningQuotas)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.provisioningQuotas.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instanceProvisioningSettings:fetch","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceProvisioningSettings:fetch)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instanceProvisioningSettings.fetch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks/{networksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks:listNetworkUsage","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks:listNetworkUsage)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.listNetworkUsage"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.operations.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs/{provisioningConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningQuotas","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningQuotas)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningQuotas.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/sshKeys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshKeys)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.sshKeys.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/luns","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/luns)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.luns.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/luns/{lunsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/luns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.luns.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks/{networksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs/{provisioningConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.cancel"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}:submitProvisioningConfig","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::submitProvisioningConfig)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.submitProvisioningConfig"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:detachLun","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachLun)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.detachLun"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:disableInteractiveSerialConsole","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableInteractiveSerialConsole)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.disableInteractiveSerialConsole"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:enableInteractiveSerialConsole","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableInteractiveSerialConsole)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.enableInteractiveSerialConsole"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reset","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.reset"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:start","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.start"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:stop","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.stop"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks/{networksId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs:submit","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs:submit)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.submit"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/sshKeys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshKeys)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.sshKeys.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/luns/{lunsId}:evict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/luns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evict)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.luns.evict"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots/{snapshotsId}:restoreVolumeSnapshot","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restoreVolumeSnapshot)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.restoreVolumeSnapshot"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}:evict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evict)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.evict"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}:resize","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resize)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.resize"},{"hostname":"batch.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.delete"},{"hostname":"batch.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.delete"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.batch","resource_name":"batch.projects.locations.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.get"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.get"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/taskGroups/{taskGroupsId}/tasks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taskGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.taskGroups.tasks.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/taskGroups/{taskGroupsId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taskGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.taskGroups.tasks.get"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.get"},{"hostname":"batch.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.create"},{"hostname":"batch.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.cancel"},{"hostname":"batch.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/state:report","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/state:report)$","service_name":"google.batch","resource_name":"batch.projects.locations.state.report"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections:resolve)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.resolve"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:resolveInstanceConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolveInstanceConfig)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.resolveInstanceConfig"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/insights","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.insights.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/insights/{insightsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.insights.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/insights/{insightsId}:configuredInsight","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configuredInsight)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.insights.configuredInsight"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections:resolve)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.resolve"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:resolveInstanceConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolveInstanceConfig)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.resolveInstanceConfig"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applications.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections:resolve)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.resolve"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:resolveInstanceConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolveInstanceConfig)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.resolveInstanceConfig"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/insights","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.insights.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/insights/{insightsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.insights.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/insights/{insightsId}:configuredInsight","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configuredInsight)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.insights.configuredInsight"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/netConnections/{netConnectionsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/netConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.netConnections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:reportStatus","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.reportStatus"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.cancel"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:reportStatus","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.reportStatus"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applications.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applications.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:reportStatus","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.reportStatus"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/netConnections/{netConnectionsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/netConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.netConnections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/netConnections/{netConnectionsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/netConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.netConnections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.cancel"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables/{tableId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models/{modelsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.models.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.routines.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/jobs/{jobsId}/delete","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/delete)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.delete"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects","path_regex":"^(?:/bigquery/v2/projects)$","service_name":"google.bigquery","resource_name":"bigquery.projects.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/datasets","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.bigquery","resource_name":"bigquery.datasets.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigquery","resource_name":"bigquery.tables.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables/{tableId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables/{tableId}/data","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data)$","service_name":"google.bigquery","resource_name":"bigquery.tabledata.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/jobs","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/jobs/{jobId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.jobs.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/queries/{jobId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.jobs.getQueryResults"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectId}/serviceAccount","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.bigquery","resource_name":"bigquery.projects.getServiceAccount"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.bigquery","resource_name":"bigquery.models.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models/{modelsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.models.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines)$","service_name":"google.bigquery","resource_name":"bigquery.routines.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.routines.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/rowAccessPolicies","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rowAccessPolicies)$","service_name":"google.bigquery","resource_name":"bigquery.rowAccessPolicies.list"},{"hostname":"bigquery.googleapis.com","http_method":"PATCH","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.patch"},{"hostname":"bigquery.googleapis.com","http_method":"PATCH","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables/{tableId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.patch"},{"hostname":"bigquery.googleapis.com","http_method":"PATCH","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models/{modelsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.models.patch"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectId}/datasets","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.bigquery","resource_name":"bigquery.datasets.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigquery","resource_name":"bigquery.tables.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables/{tableId}/insertAll","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertAll)$","service_name":"google.bigquery","resource_name":"bigquery.tabledata.insertAll"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectId}/jobs","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectId}/jobs/{jobId}/cancel","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.cancel"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectId}/queries","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.query"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines)$","service_name":"google.bigquery","resource_name":"bigquery.routines.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/rowAccessPolicies/{rowAccessPoliciesId}:getIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rowAccessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.rowAccessPolicies.getIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/rowAccessPolicies/{rowAccessPoliciesId}:setIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rowAccessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.rowAccessPolicies.setIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/rowAccessPolicies/{rowAccessPoliciesId}:testIamPermissions","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rowAccessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigquery","resource_name":"bigquery.rowAccessPolicies.testIamPermissions"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.tables.getIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.tables.setIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigquery","resource_name":"bigquery.tables.testIamPermissions"},{"hostname":"bigquery.googleapis.com","http_method":"PUT","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.update"},{"hostname":"bigquery.googleapis.com","http_method":"PUT","path_template":"/bigquery/v2/projects/{projectId}/datasets/{datasetId}/tables/{tableId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.update"},{"hostname":"bigquery.googleapis.com","http_method":"PUT","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.routines.update"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.delete"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.list"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.get"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.patch"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/credential","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credential)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.updateCredential"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.create"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.getIamPolicy"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.setIamPolicy"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.testIamPermissions"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.dataSources.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.dataSources.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.dataSources.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.dataSources.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs/{runsId}/transferLogs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferLogs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.transferLogs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs/{runsId}/transferLogs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferLogs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.transferLogs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.patch"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.patch"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/dataSources/{dataSourcesId}:checkValidCreds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkValidCreds)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.dataSources.checkValidCreds"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataSources/{dataSourcesId}:checkValidCreds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkValidCreds)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.dataSources.checkValidCreds"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.create"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}:scheduleRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::scheduleRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.scheduleRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}:startManualRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startManualRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.startManualRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:enrollDataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enrollDataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.enrollDataSources"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.create"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}:scheduleRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::scheduleRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.scheduleRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}:startManualRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startManualRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.startManualRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:enrollDataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enrollDataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.enrollDataSources"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservationGrants/{reservationGrantsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservationGrants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservationGrants.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/slotPools/{slotPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slotPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.slotPools.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.getBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:searchAllAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAllAssignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchAllAssignments"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:searchAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAssignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchAssignments"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.operations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservationGrants","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservationGrants)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservationGrants.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/slotPools","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slotPools)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.slotPools.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/slotPools/{slotPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slotPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.slotPools.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}:SearchReservationGrants","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::SearchReservationGrants)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchReservationGrants"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.getBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}:searchAssignments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAssignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchAssignments"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.updateBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/{reservationsId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.updateBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}:split","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::split)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.split"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments:merge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments:merge)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.merge"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}:move","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.move"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.operations.cancel"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservationGrants","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservationGrants)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservationGrants.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.createReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}:split","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::split)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.split"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments:merge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments:merge)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.merge"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}:move","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.move"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/operations/{operationsId}","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.operations.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles/{appProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/operations/projects/{projectsId}/operations","path_regex":"^(?:/v2/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.operations.projects.operations.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/operations/{operationsId}","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.operations.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles/{appProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/hotTablets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hotTablets)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.hotTablets.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.locations.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.locations.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.partialUpdateInstance"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles/{appProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.patch"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.partialUpdateCluster"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.patch"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.patch"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/operations/{operationsId}:cancel","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.operations.cancel"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.getIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.setIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.testIamPermissions"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups:copy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups:copy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.copy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:checkConsistency","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkConsistency)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.checkConsistency"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:dropRowRange","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dropRowRange)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.dropRowRange"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:generateConsistencyToken","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConsistencyToken)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.generateConsistencyToken"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.getIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:modifyColumnFamilies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyColumnFamilies)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.modifyColumnFamilies"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.setIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.testIamPermissions"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:undelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.undelete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables:restore","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables:restore)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.restore"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.getIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.setIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.testIamPermissions"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.update"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.update"},{"hostname":"billingbudgets.googleapis.com","http_method":"DELETE","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.delete"},{"hostname":"billingbudgets.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.delete"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.list"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.get"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.list"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.get"},{"hostname":"billingbudgets.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.patch"},{"hostname":"billingbudgets.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.patch"},{"hostname":"billingbudgets.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.create"},{"hostname":"billingbudgets.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.create"},{"hostname":"binaryauthorization.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.delete"},{"hostname":"binaryauthorization.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.delete"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/policy","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.systempolicy.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/attestors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.list"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.get"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/policy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/policy:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/locations/{locationsId}/policy","path_regex":"^(?:/v1beta1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.systempolicy.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/attestors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.list"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.get"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/policy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/policy:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.create"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:validateAttestationOccurrence","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateAttestationOccurrence)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.validateAttestationOccurrence"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/policy:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/policy:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.create"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:validateAttestationOccurrence","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateAttestationOccurrence)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.validateAttestationOccurrence"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/policy:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/policy:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.update"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/policy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.updatePolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.update"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/policy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.updatePolicy"},{"hostname":"blogger.googleapis.com","http_method":"DELETE","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.delete"},{"hostname":"blogger.googleapis.com","http_method":"DELETE","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.delete"},{"hostname":"blogger.googleapis.com","http_method":"DELETE","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.delete"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogs.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/pages","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts/{postId}/comments","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/users/{userId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.users.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/users/{userId}/blogs","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs)$","service_name":"google.blogger","resource_name":"blogger.blogs.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/byurl","path_regex":"^(?:/v3/blogs/byurl)$","service_name":"google.blogger","resource_name":"blogger.blogs.getByUrl"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogs.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/comments","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.listByBlog"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/pages","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/pageviews","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pageviews)$","service_name":"google.blogger","resource_name":"blogger.pageViews.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/bypath","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/bypath)$","service_name":"google.blogger","resource_name":"blogger.posts.getByPath"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/search","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/search)$","service_name":"google.blogger","resource_name":"blogger.posts.search"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.users.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs)$","service_name":"google.blogger","resource_name":"blogger.blogs.listByUser"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs/{blogId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogUserInfos.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs/{blogId}/posts","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.get"},{"hostname":"blogger.googleapis.com","http_method":"PATCH","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.patch"},{"hostname":"blogger.googleapis.com","http_method":"PATCH","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.patch"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/pages","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.insert"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/pages/{pageId}/publish","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.blogger","resource_name":"blogger.pages.publish"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/pages/{pageId}/revert","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revert)$","service_name":"google.blogger","resource_name":"blogger.pages.revert"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.insert"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/approve","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approve)$","service_name":"google.blogger","resource_name":"blogger.comments.approve"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/removecontent","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removecontent)$","service_name":"google.blogger","resource_name":"blogger.comments.removeContent"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/spam","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spam)$","service_name":"google.blogger","resource_name":"blogger.comments.markAsSpam"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/publish","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.blogger","resource_name":"blogger.posts.publish"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/revert","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revert)$","service_name":"google.blogger","resource_name":"blogger.posts.revert"},{"hostname":"blogger.googleapis.com","http_method":"PUT","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.update"},{"hostname":"blogger.googleapis.com","http_method":"PUT","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.update"},{"hostname":"books.googleapis.com","http_method":"DELETE","path_template":"/books/v1/mylibrary/annotations/{annotationId}","path_regex":"^(?:/books/v1/mylibrary/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.annotations.delete"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/dictionary/listOfflineMetadata","path_regex":"^(?:/books/v1/dictionary/listOfflineMetadata)$","service_name":"google.books","resource_name":"books.dictionary.listOfflineMetadata"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/familysharing/getFamilyInfo","path_regex":"^(?:/books/v1/familysharing/getFamilyInfo)$","service_name":"google.books","resource_name":"books.familysharing.getFamilyInfo"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/myconfig/getUserSettings","path_regex":"^(?:/books/v1/myconfig/getUserSettings)$","service_name":"google.books","resource_name":"books.myconfig.getUserSettings"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/annotations","path_regex":"^(?:/books/v1/mylibrary/annotations)$","service_name":"google.books","resource_name":"books.mylibrary.annotations.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/bookshelves","path_regex":"^(?:/books/v1/mylibrary/bookshelves)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/bookshelves/{shelf}","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/volumes","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.volumes.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/readingpositions/{volumeId}","path_regex":"^(?:/books/v1/mylibrary/readingpositions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.readingpositions.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/notification/get","path_regex":"^(?:/books/v1/notification/get)$","service_name":"google.books","resource_name":"books.notification.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/onboarding/listCategories","path_regex":"^(?:/books/v1/onboarding/listCategories)$","service_name":"google.books","resource_name":"books.onboarding.listCategories"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/onboarding/listCategoryVolumes","path_regex":"^(?:/books/v1/onboarding/listCategoryVolumes)$","service_name":"google.books","resource_name":"books.onboarding.listCategoryVolumes"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/personalizedstream/get","path_regex":"^(?:/books/v1/personalizedstream/get)$","service_name":"google.books","resource_name":"books.personalizedstream.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/promooffer/get","path_regex":"^(?:/books/v1/promooffer/get)$","service_name":"google.books","resource_name":"books.promooffer.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/series/get","path_regex":"^(?:/books/v1/series/get)$","service_name":"google.books","resource_name":"books.series.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/series/membership/get","path_regex":"^(?:/books/v1/series/membership/get)$","service_name":"google.books","resource_name":"books.series.membership.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/users/{userId}/bookshelves","path_regex":"^(?:/books/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bookshelves)$","service_name":"google.books","resource_name":"books.bookshelves.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/users/{userId}/bookshelves/{shelf}","path_regex":"^(?:/books/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.bookshelves.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/users/{userId}/bookshelves/{shelf}/volumes","path_regex":"^(?:/books/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes)$","service_name":"google.books","resource_name":"books.bookshelves.volumes.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes","path_regex":"^(?:/books/v1/volumes)$","service_name":"google.books","resource_name":"books.volumes.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/mybooks","path_regex":"^(?:/books/v1/volumes/mybooks)$","service_name":"google.books","resource_name":"books.volumes.mybooks.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/recommended","path_regex":"^(?:/books/v1/volumes/recommended)$","service_name":"google.books","resource_name":"books.volumes.recommended.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/useruploaded","path_regex":"^(?:/books/v1/volumes/useruploaded)$","service_name":"google.books","resource_name":"books.volumes.useruploaded.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.volumes.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/associated","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associated)$","service_name":"google.books","resource_name":"books.volumes.associated.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.volumeAnnotations.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}/annotations/{annotationId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.volumeAnnotations.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}/data","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data)$","service_name":"google.books","resource_name":"books.layers.annotationData.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}/data/{annotationDataId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.annotationData.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layersummary","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layersummary)$","service_name":"google.books","resource_name":"books.layers.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layersummary/{summaryId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layersummary/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.get"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/cloudloading/addBook","path_regex":"^(?:/books/v1/cloudloading/addBook)$","service_name":"google.books","resource_name":"books.cloudloading.addBook"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/cloudloading/deleteBook","path_regex":"^(?:/books/v1/cloudloading/deleteBook)$","service_name":"google.books","resource_name":"books.cloudloading.deleteBook"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/cloudloading/updateBook","path_regex":"^(?:/books/v1/cloudloading/updateBook)$","service_name":"google.books","resource_name":"books.cloudloading.updateBook"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/familysharing/share","path_regex":"^(?:/books/v1/familysharing/share)$","service_name":"google.books","resource_name":"books.familysharing.share"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/familysharing/unshare","path_regex":"^(?:/books/v1/familysharing/unshare)$","service_name":"google.books","resource_name":"books.familysharing.unshare"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/releaseDownloadAccess","path_regex":"^(?:/books/v1/myconfig/releaseDownloadAccess)$","service_name":"google.books","resource_name":"books.myconfig.releaseDownloadAccess"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/requestAccess","path_regex":"^(?:/books/v1/myconfig/requestAccess)$","service_name":"google.books","resource_name":"books.myconfig.requestAccess"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/syncVolumeLicenses","path_regex":"^(?:/books/v1/myconfig/syncVolumeLicenses)$","service_name":"google.books","resource_name":"books.myconfig.syncVolumeLicenses"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/updateUserSettings","path_regex":"^(?:/books/v1/myconfig/updateUserSettings)$","service_name":"google.books","resource_name":"books.myconfig.updateUserSettings"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/annotations","path_regex":"^(?:/books/v1/mylibrary/annotations)$","service_name":"google.books","resource_name":"books.mylibrary.annotations.insert"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/annotations/summary","path_regex":"^(?:/books/v1/mylibrary/annotations/summary)$","service_name":"google.books","resource_name":"books.mylibrary.annotations.summary"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/addVolume","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addVolume)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.addVolume"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/clearVolumes","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clearVolumes)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.clearVolumes"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/moveVolume","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveVolume)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.moveVolume"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/removeVolume","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeVolume)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.removeVolume"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/readingpositions/{volumeId}/setPosition","path_regex":"^(?:/books/v1/mylibrary/readingpositions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPosition)$","service_name":"google.books","resource_name":"books.mylibrary.readingpositions.setPosition"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/promooffer/accept","path_regex":"^(?:/books/v1/promooffer/accept)$","service_name":"google.books","resource_name":"books.promooffer.accept"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/promooffer/dismiss","path_regex":"^(?:/books/v1/promooffer/dismiss)$","service_name":"google.books","resource_name":"books.promooffer.dismiss"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/volumes/recommended/rate","path_regex":"^(?:/books/v1/volumes/recommended/rate)$","service_name":"google.books","resource_name":"books.volumes.recommended.rate"},{"hostname":"books.googleapis.com","http_method":"PUT","path_template":"/books/v1/mylibrary/annotations/{annotationId}","path_regex":"^(?:/books/v1/mylibrary/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.annotations.update"},{"hostname":"businessprofileperformance.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/searchkeywords/impressions/monthly","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchkeywords/impressions/monthly)$","service_name":"google.businessprofileperformance","resource_name":"businessprofileperformance.locations.searchkeywords.impressions.monthly.list"},{"hostname":"businessprofileperformance.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}:fetchMultiDailyMetricsTimeSeries","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchMultiDailyMetricsTimeSeries)$","service_name":"google.businessprofileperformance","resource_name":"businessprofileperformance.locations.fetchMultiDailyMetricsTimeSeries"},{"hostname":"businessprofileperformance.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}:getDailyMetricsTimeSeries","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDailyMetricsTimeSeries)$","service_name":"google.businessprofileperformance","resource_name":"businessprofileperformance.locations.getDailyMetricsTimeSeries"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs/{certificateIssuanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries/{certificateMapEntriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations/{dnsAuthorizationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs/{trustConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs/{certificateIssuanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries/{certificateMapEntriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations/{dnsAuthorizationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs/{trustConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries/{certificateMapEntriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations/{dnsAuthorizationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs/{trustConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.cancel"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.create"},{"hostname":"chat.googleapis.com","http_method":"DELETE","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.delete"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.media.download"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces","path_regex":"^(?:/v1/spaces)$","service_name":"google.chat","resource_name":"chat.spaces.list"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/members","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.chat","resource_name":"chat.spaces.members.list"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/members/{membersId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.members.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.attachments.get"},{"hostname":"chat.googleapis.com","http_method":"PATCH","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.patch"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces/{spacesId}/messages","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.chat","resource_name":"chat.spaces.messages.create"},{"hostname":"chat.googleapis.com","http_method":"PUT","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.update"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps/android/{androidId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/android/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.android.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps/chrome/{chromeId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/chrome/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.chrome.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps/web/{webId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/web/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.web.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps:countChromeAppRequests","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps:countChromeAppRequests)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.countChromeAppRequests"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeBrowsersNeedingAttention","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeBrowsersNeedingAttention)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeBrowsersNeedingAttention"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeDevicesReachingAutoExpirationDate","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeDevicesReachingAutoExpirationDate)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeDevicesReachingAutoExpirationDate"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeDevicesThatNeedAttention","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeDevicesThatNeedAttention)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeDevicesThatNeedAttention"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeHardwareFleetDevices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeHardwareFleetDevices)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeHardwareFleetDevices"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeVersions","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeVersions)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeVersions"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countInstalledApps","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countInstalledApps)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countInstalledApps"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:findInstalledAppDevices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:findInstalledAppDevices)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.findInstalledAppDevices"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/devices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/devices)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.devices.list"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/devices/{devicesId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.devices.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/events","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/events)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.events.list"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/users","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/users)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.users.list"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/users/{usersId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.users.get"},{"hostname":"chromepolicy.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/policySchemas","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policySchemas)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policySchemas.list"},{"hostname":"chromepolicy.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/policySchemas/{policySchemasId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policySchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policySchemas.get"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/files:uploadPolicyFile","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/files:uploadPolicyFile)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.media.upload"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:batchDelete","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:batchDelete)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.batchDelete"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:batchModify","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:batchModify)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.batchModify"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:listGroupPriorityOrdering","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:listGroupPriorityOrdering)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.listGroupPriorityOrdering"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:updateGroupPriorityOrdering","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:updateGroupPriorityOrdering)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.updateGroupPriorityOrdering"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:defineCertificate","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:defineCertificate)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.defineCertificate"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:defineNetwork","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:defineNetwork)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.defineNetwork"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:removeCertificate","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:removeCertificate)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.removeCertificate"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:removeNetwork","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:removeNetwork)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.removeNetwork"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/orgunits:batchInherit","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/orgunits:batchInherit)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.orgunits.batchInherit"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/orgunits:batchModify","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/orgunits:batchModify)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.orgunits.batchModify"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies:resolve","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies:resolve)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.resolve"},{"hostname":"chromeuxreport.googleapis.com","http_method":"POST","path_template":"/v1/records:queryHistoryRecord","path_regex":"^(?:/v1/records:queryHistoryRecord)$","service_name":"google.chromeuxreport","resource_name":"chromeuxreport.records.queryHistoryRecord"},{"hostname":"chromeuxreport.googleapis.com","http_method":"POST","path_template":"/v1/records:queryRecord","path_regex":"^(?:/v1/records:queryRecord)$","service_name":"google.chromeuxreport","resource_name":"chromeuxreport.records.queryRecord"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/divisions","path_regex":"^(?:/civicinfo/v2/divisions)$","service_name":"google.civicinfo","resource_name":"civicinfo.divisions.search"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/elections","path_regex":"^(?:/civicinfo/v2/elections)$","service_name":"google.civicinfo","resource_name":"civicinfo.elections.electionQuery"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/representatives","path_regex":"^(?:/civicinfo/v2/representatives)$","service_name":"google.civicinfo","resource_name":"civicinfo.representatives.representativeInfoByAddress"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/representatives/{ocdId}","path_regex":"^(?:/civicinfo/v2/representatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.civicinfo","resource_name":"civicinfo.representatives.representativeInfoByDivision"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/voterinfo","path_regex":"^(?:/civicinfo/v2/voterinfo)$","service_name":"google.civicinfo","resource_name":"civicinfo.elections.voterInfoQuery"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/aliases/{alias}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.aliases.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/announcements/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/courseWork/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/students/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.students.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/teachers/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/topics/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.topics.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/invitations/{id}","path_regex":"^(?:/v1/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.invitations.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/registrations/{registrationId}","path_regex":"^(?:/v1/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.registrations.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/userProfiles/{studentId}/guardians/{guardianId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardians/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardians.delete"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses","path_regex":"^(?:/v1/courses)$","service_name":"google.classroom","resource_name":"classroom.courses.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/aliases","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.classroom","resource_name":"classroom.courses.aliases.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/announcements","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/announcements/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWorkMaterials","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/students","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students)$","service_name":"google.classroom","resource_name":"classroom.courses.students.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/students/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.students.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/teachers","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers)$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/teachers/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/topics","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.classroom","resource_name":"classroom.courses.topics.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/topics/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.topics.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/invitations","path_regex":"^(?:/v1/invitations)$","service_name":"google.classroom","resource_name":"classroom.invitations.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/invitations/{id}","path_regex":"^(?:/v1/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.invitations.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardianInvitations","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations)$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardianInvitations/{invitationId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardians","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardians)$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardians.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardians/{guardianId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardians/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardians.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{userId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.get"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/announcements/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWork/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/topics/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.topics.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/userProfiles/{studentId}/guardianInvitations/{invitationId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.patch"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses","path_regex":"^(?:/v1/courses)$","service_name":"google.classroom","resource_name":"classroom.courses.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/aliases","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.classroom","resource_name":"classroom.courses.aliases.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/announcements","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/announcements/{id}:modifyAssignees","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAssignees)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.modifyAssignees"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:modifyAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.modifyAttachments"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:reclaim","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reclaim)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.reclaim"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:return","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::return)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.return"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:turnIn","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::turnIn)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.turnIn"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{id}:modifyAssignees","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAssignees)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.modifyAssignees"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWorkMaterials","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/students","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students)$","service_name":"google.classroom","resource_name":"classroom.courses.students.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/teachers","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers)$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/topics","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.classroom","resource_name":"classroom.courses.topics.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/invitations","path_regex":"^(?:/v1/invitations)$","service_name":"google.classroom","resource_name":"classroom.invitations.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/invitations/{id}:accept","path_regex":"^(?:/v1/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.classroom","resource_name":"classroom.invitations.accept"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/registrations","path_regex":"^(?:/v1/registrations)$","service_name":"google.classroom","resource_name":"classroom.registrations.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/userProfiles/{studentId}/guardianInvitations","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations)$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.create"},{"hostname":"classroom.googleapis.com","http_method":"PUT","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.update"},{"hostname":"cloudasset.googleapis.com","http_method":"DELETE","path_template":"/v1/{v1Id}/{v1Id1}/feeds/{feedsId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.delete"},{"hostname":"cloudasset.googleapis.com","http_method":"DELETE","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.delete"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/assets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.cloudasset","resource_name":"cloudasset.assets.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/effectiveIamPolicies:batchGet","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/effectiveIamPolicies:batchGet)$","service_name":"google.cloudasset","resource_name":"cloudasset.effectiveIamPolicies.batchGet"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/feeds","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds)$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/feeds/{feedsId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeIamPolicy)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeIamPolicy"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeMove","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeMove)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeMove"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeOrgPolicies","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeOrgPolicies)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeOrgPolicies"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeOrgPolicyGovernedAssets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeOrgPolicyGovernedAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeOrgPolicyGovernedAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeOrgPolicyGovernedContainers","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeOrgPolicyGovernedContainers)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeOrgPolicyGovernedContainers"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:batchGetAssetsHistory","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchGetAssetsHistory)$","service_name":"google.cloudasset","resource_name":"cloudasset.batchGetAssetsHistory"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:searchAllIamPolicies","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAllIamPolicies)$","service_name":"google.cloudasset","resource_name":"cloudasset.searchAllIamPolicies"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:searchAllResources","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAllResources)$","service_name":"google.cloudasset","resource_name":"cloudasset.searchAllResources"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.folders.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.organizations.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}:batchGetAssetsHistory","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchGetAssetsHistory)$","service_name":"google.cloudasset","resource_name":"cloudasset.organizations.batchGetAssetsHistory"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.projects.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}:batchGetAssetsHistory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchGetAssetsHistory)$","service_name":"google.cloudasset","resource_name":"cloudasset.projects.batchGetAssetsHistory"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/{v1p1beta1Id}/{v1p1beta1Id1}/iamPolicies:searchAll","path_regex":"^(?:/v1p1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iamPolicies:searchAll)$","service_name":"google.cloudasset","resource_name":"cloudasset.iamPolicies.searchAll"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/{v1p1beta1Id}/{v1p1beta1Id1}/resources:searchAll","path_regex":"^(?:/v1p1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources:searchAll)$","service_name":"google.cloudasset","resource_name":"cloudasset.resources.searchAll"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p4beta1/{v1p4beta1Id}/{v1p4beta1Id1}:analyzeIamPolicy","path_regex":"^(?:/v1p4beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeIamPolicy)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeIamPolicy"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p5beta1/{v1p5beta1Id}/{v1p5beta1Id1}/assets","path_regex":"^(?:/v1p5beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.cloudasset","resource_name":"cloudasset.assets.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p7beta1/{v1p7beta1Id}/{v1p7beta1Id1}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1p7beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"PATCH","path_template":"/v1/{v1Id}/{v1Id1}/feeds/{feedsId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.patch"},{"hostname":"cloudasset.googleapis.com","http_method":"PATCH","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.patch"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/feeds","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds)$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.create"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.create"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}:analyzeIamPolicyLongrunning","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeIamPolicyLongrunning)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeIamPolicyLongrunning"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}:exportAssets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}:queryAssets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.queryAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}:exportAssets","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.folders.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:exportAssets","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.organizations.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:exportAssets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.projects.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1p4beta1/{v1p4beta1Id}/{v1p4beta1Id1}:exportIamPolicyAnalysis","path_regex":"^(?:/v1p4beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportIamPolicyAnalysis)$","service_name":"google.cloudasset","resource_name":"cloudasset.exportIamPolicyAnalysis"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1p7beta1/{v1p7beta1Id}/{v1p7beta1Id1}:exportAssets","path_regex":"^(?:/v1p7beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.exportAssets"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts","path_regex":"^(?:/v1/billingAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/projects","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.projects.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}:getIamPolicy","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.getIamPolicy"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/billingInfo","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingInfo)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.projects.getBillingInfo"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/services","path_regex":"^(?:/v1/services)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.services.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/skus","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.services.skus.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.patch"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts","path_regex":"^(?:/v1/billingAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.create"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}:setIamPolicy","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.setIamPolicy"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}:testIamPermissions","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.testIamPermissions"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1beta/billingAccounts/{billingAccountsId}:estimateCostScenario","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::estimateCostScenario)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.estimateCostScenario"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1beta:estimateCostScenario","path_regex":"^(?:/v1beta:estimateCostScenario)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.estimateCostScenario"},{"hostname":"cloudbilling.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/billingInfo","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingInfo)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.projects.updateBillingInfo"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/triggers/{triggerId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/builds/{id}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/triggers/{triggerId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.repos.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.repos.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/triggers/{triggerId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/githubDotComWebhook:receive","path_regex":"^(?:/v1/githubDotComWebhook:receive)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.githubDotComWebhook.receive"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/regionalWebhook","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalWebhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.locations.regionalWebhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/builds/{id}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/builds/{id}:retry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retry)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.retry"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/triggers/{triggerId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.run"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/triggers/{trigger}:webhook","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::webhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.webhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/builds/{buildsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.approve"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}/connectedRepositories:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectedRepositories:batchCreate)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.connectedRepositories.batchCreate"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}:removeBitbucketServerConnectedRepository","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeBitbucketServerConnectedRepository)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.removeBitbucketServerConnectedRepository"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.approve"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}:retry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retry)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.retry"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}/connectedRepositories:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectedRepositories:batchCreate)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.connectedRepositories.batchCreate"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}:removeGitLabConnectedRepository","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeGitLabConnectedRepository)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.removeGitLabConnectedRepository"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.run"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:webhook","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::webhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.webhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/webhook","path_regex":"^(?:/v1/webhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.webhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs/{channelPartnerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs/{customerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs/{channelPartnerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs/{customerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:listEntitlementChanges","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listEntitlementChanges)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.listEntitlementChanges"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:lookupOffer","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupOffer)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.lookupOffer"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:listPurchasableOffers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listPurchasableOffers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.listPurchasableOffers"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:listPurchasableSkus","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listPurchasableSkus)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.listPurchasableSkus"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/offers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.offers.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/reports","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.reports.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}:listSubscribers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSubscribers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.listSubscribers"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/products","path_regex":"^(?:/v1/products)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.products.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/products/{productsId}/skus","path_regex":"^(?:/v1/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.products.skus.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs/{channelPartnerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs/{customerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers:import","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers:import)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.import"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:activate","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.activate"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:cancel","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.cancel"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:changeOffer","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::changeOffer)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.changeOffer"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:changeParameters","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::changeParameters)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.changeParameters"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:changeRenewalSettings","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::changeRenewalSettings)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.changeRenewalSettings"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:startPaidService","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startPaidService)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.startPaidService"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:suspend","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::suspend)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.suspend"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:provisionCloudIdentity","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::provisionCloudIdentity)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.provisionCloudIdentity"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:transferEntitlements","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::transferEntitlements)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.transferEntitlements"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:transferEntitlementsToGoogle","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::transferEntitlementsToGoogle)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.transferEntitlementsToGoogle"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers:import","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers:import)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.import"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/reportJobs/{reportJobsId}:fetchReportResults","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchReportResults)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.reportJobs.fetchReportResults"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/reports/{reportsId}:run","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.reports.run"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:checkCloudIdentityAccountsExist","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkCloudIdentityAccountsExist)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.checkCloudIdentityAccountsExist"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:listTransferableOffers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTransferableOffers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.listTransferableOffers"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:listTransferableSkus","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTransferableSkus)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.listTransferableSkus"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:register","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::register)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.register"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:unregister","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unregister)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.unregister"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.cancel"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/accounts","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.list"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/accounts/{accountsId}","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.get"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/entitlements","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.list"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.get"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"PATCH","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.patch"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/accounts/{accountsId}:approve","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.approve"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/accounts/{accountsId}:reject","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.reject"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/accounts/{accountsId}:reset","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.reset"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:approve","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.approve"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:approvePlanChange","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approvePlanChange)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.approvePlanChange"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:reject","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.reject"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:rejectPlanChange","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rejectPlanChange)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.rejectPlanChange"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:suspend","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::suspend)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.suspend"},{"hostname":"clouddebugger.googleapis.com","http_method":"DELETE","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints/{breakpointId}","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.delete"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/controller/debuggees/{debuggeeId}/breakpoints","path_regex":"^(?:/v2/controller/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.controller.debuggees.breakpoints.list"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/debugger/debuggees","path_regex":"^(?:/v2/debugger/debuggees)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.list"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.list"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints/{breakpointId}","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.get"},{"hostname":"clouddebugger.googleapis.com","http_method":"POST","path_template":"/v2/controller/debuggees/register","path_regex":"^(?:/v2/controller/debuggees/register)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.controller.debuggees.register"},{"hostname":"clouddebugger.googleapis.com","http_method":"POST","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints/set","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/set)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.set"},{"hostname":"clouddebugger.googleapis.com","http_method":"PUT","path_template":"/v2/controller/debuggees/{debuggeeId}/breakpoints/{id}","path_regex":"^(?:/v2/controller/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddebugger","resource_name":"clouddebugger.controller.debuggees.breakpoints.update"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.getConfig"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}/jobRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobRuns)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.jobRuns.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}/jobRuns/{jobRunsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.jobRuns.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.getIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.getIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.patch"},{"hostname":"clouddeploy.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.patch"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}/jobRuns/{jobRunsId}:terminate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::terminate)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.jobRuns.terminate"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:advance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::advance)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.advance"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.approve"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.cancel"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:ignoreJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::ignoreJob)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.ignoreJob"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:retryJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retryJob)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.retryJob"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}:abandon","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::abandon)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.abandon"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.setIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.testIamPermissions"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.cancel"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.setIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.testIamPermissions"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/events","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.deleteEvents"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/events","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.events.list"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/groupStats","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupStats)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.groupStats.list"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.groups.get"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/events:report","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events:report)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.events.report"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.groups.update"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/operations","path_regex":"^(?:/v1beta2/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/operations/{operationsId}","path_regex":"^(?:/v1beta2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.runtimes.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.runtimes.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.runtimes.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:call","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::call)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.call"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:call","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::call)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.call"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.update"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/devices/{devicesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/groups/{groupsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/devices/{devicesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/groups/{groupsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1beta1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/userinvitations","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}:isInvitableUser","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::isInvitableUser)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.isInvitableUser"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices","path_regex":"^(?:/v1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers:lookup","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups","path_regex":"^(?:/v1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:checkTransitiveMembership","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:checkTransitiveMembership)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.checkTransitiveMembership"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:getMembershipGraph","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:getMembershipGraph)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.getMembershipGraph"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:lookup","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:searchDirectGroups","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchDirectGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchDirectGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:searchTransitiveGroups","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:searchTransitiveMemberships","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveMemberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveMemberships"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.getSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups:lookup","path_regex":"^(?:/v1/groups:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups:search","path_regex":"^(?:/v1/groups:search)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.search"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles","path_regex":"^(?:/v1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSsoAssignments","path_regex":"^(?:/v1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/customers/{customersId}/userinvitations","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}:isInvitableUser","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::isInvitableUser)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.isInvitableUser"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices","path_regex":"^(?:/v1beta1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers:lookup","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups","path_regex":"^(?:/v1beta1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:checkTransitiveMembership","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:checkTransitiveMembership)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.checkTransitiveMembership"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:getMembershipGraph","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:getMembershipGraph)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.getMembershipGraph"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:lookup","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:searchDirectGroups","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchDirectGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchDirectGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:searchTransitiveGroups","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:searchTransitiveMemberships","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveMemberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveMemberships"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.getSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups:lookup","path_regex":"^(?:/v1beta1/groups:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups:search","path_regex":"^(?:/v1beta1/groups:search)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.search"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSsoAssignments","path_regex":"^(?:/v1beta1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1beta1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/orgUnits/{orgUnitsId}/memberships","path_regex":"^(?:/v1beta1/orgUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.orgUnits.memberships.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/groups/{groupsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.updateSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/groups/{groupsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.updateSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1beta1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}:cancel","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.cancel"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}:send","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::send)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.send"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices","path_regex":"^(?:/v1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:approve","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.approve"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:block","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::block)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.block"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:cancelWipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:wipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}:cancelWipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}:wipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/groups","path_regex":"^(?:/v1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/groups/{groupsId}/memberships","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/groups/{groupsId}/memberships/{membershipsId}:modifyMembershipRoles","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyMembershipRoles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.modifyMembershipRoles"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/inboundSamlSsoProfiles","path_regex":"^(?:/v1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials:add","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials:add)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.add"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/inboundSsoAssignments","path_regex":"^(?:/v1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}:cancel","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.cancel"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}:send","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::send)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.send"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices","path_regex":"^(?:/v1beta1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:approve","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.approve"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:block","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::block)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.block"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:cancelWipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:wipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}:cancelWipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}:wipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/groups","path_regex":"^(?:/v1beta1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/groups/{groupsId}/memberships","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/groups/{groupsId}/memberships/{membershipsId}:modifyMembershipRoles","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyMembershipRoles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.modifyMembershipRoles"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/inboundSamlSsoProfiles","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials:add","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials:add)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.add"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/inboundSsoAssignments","path_regex":"^(?:/v1beta1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/orgUnits/{orgUnitsId}/memberships/{membershipsId}:move","path_regex":"^(?:/v1beta1/orgUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.orgUnits.memberships.move"},{"hostname":"cloudiot.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.delete"},{"hostname":"cloudiot.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.delete"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.get"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.get"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}/configVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configVersions)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.configVersions.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}/states","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/states)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.states.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}/devices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.devices.list"},{"hostname":"cloudiot.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.patch"},{"hostname":"cloudiot.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.patch"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.create"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.create"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}:modifyCloudToDeviceConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyCloudToDeviceConfig)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.modifyCloudToDeviceConfig"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}:sendCommandToDevice","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sendCommandToDevice)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.sendCommandToDevice"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.getIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.setIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.testIamPermissions"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:bindDeviceToGateway","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bindDeviceToGateway)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.bindDeviceToGateway"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.getIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.setIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.testIamPermissions"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:unbindDeviceFromGateway","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unbindDeviceFromGateway)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.unbindDeviceFromGateway"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.getEkmConfig"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig:getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConfig.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:verifyConnectivity","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verifyConnectivity)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.verifyConnectivity"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}/publicKey","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicKey)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.getPublicKey"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.updateEkmConfig"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.patch"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.patch"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.patch"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig:setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConfig.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig:testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConfig.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:asymmetricDecrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::asymmetricDecrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.asymmetricDecrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:asymmetricSign","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::asymmetricSign)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.asymmetricSign"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:destroy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.destroy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:macSign","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::macSign)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.macSign"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:macVerify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::macVerify)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.macVerify"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.restore"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions:import)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.import"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:decrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.decrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:encrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::encrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.encrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:updatePrimaryVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updatePrimaryVersion)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.updatePrimaryVersion"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:generateRandomBytes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateRandomBytes)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.generateRandomBytes"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/catalogs:search","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.folders.catalogs.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/products:search","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.folders.products.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/versions:search","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.folders.versions.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/catalogs:search","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.organizations.catalogs.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/products:search","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.organizations.products.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/versions:search","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.organizations.versions.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/catalogs:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.projects.catalogs.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/products:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.projects.products.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/versions:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.projects.versions.search"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}/associations/{associationsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs","path_regex":"^(?:/v1beta1/catalogs)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/associations","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/associations/{associationsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}:getIamPolicy","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.getIamPolicy"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.patch"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.patch"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.patch"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs","path_regex":"^(?:/v1beta1/catalogs)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/associations","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/icons:upload","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/icons:upload)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.icons.upload"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}:copy","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::copy)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.copy"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}:setIamPolicy","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.setIamPolicy"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}:testIamPermissions","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.testIamPermissions"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}:undelete","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.undelete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.cancel"},{"hostname":"cloudprofiler.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/profiles/{profilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprofiler","resource_name":"cloudprofiler.projects.profiles.patch"},{"hostname":"cloudprofiler.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/profiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.cloudprofiler","resource_name":"cloudprofiler.projects.profiles.create"},{"hostname":"cloudprofiler.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/profiles:createOffline","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles:createOffline)$","service_name":"google.cloudprofiler","resource_name":"cloudprofiler.projects.profiles.createOffline"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/liens/{liensId}","path_regex":"^(?:/v1/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/folders/{foldersId}","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/liens/{liensId}","path_regex":"^(?:/v3/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagBindings/{tagBindingsId}","path_regex":"^(?:/v3/tagBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagBindings.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagKeys/{tagKeysId}","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagValues/{tagValuesId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagValues/{tagValuesId}/tagHolds/{tagHoldsId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagHolds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.tagHolds.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/liens","path_regex":"^(?:/v1/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/liens/{liensId}","path_regex":"^(?:/v1/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/{+name}","path_regex":"^(?:/v1/)((?:(?:[\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e\\x21\\x23\\x24\\x26-\\x2c\\x2f\\x3a\\x3b\\x3d\\x3f\\x40\\x5b\\x5d]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations","path_regex":"^(?:/v1beta1/organizations)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects","path_regex":"^(?:/v1beta1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/effectiveTags","path_regex":"^(?:/v3/effectiveTags)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.effectiveTags.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/folders","path_regex":"^(?:/v3/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/folders/{foldersId}","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/folders:search","path_regex":"^(?:/v3/folders:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/liens","path_regex":"^(?:/v3/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/liens/{liensId}","path_regex":"^(?:/v3/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/operations/{operationsId}","path_regex":"^(?:/v3/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/organizations/{organizationsId}","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/organizations:search","path_regex":"^(?:/v3/organizations:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/projects","path_regex":"^(?:/v3/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/projects:search","path_regex":"^(?:/v3/projects:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagBindings","path_regex":"^(?:/v3/tagBindings)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagBindings.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagKeys","path_regex":"^(?:/v3/tagKeys)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagKeys/namespaced","path_regex":"^(?:/v3/tagKeys/namespaced)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.getNamespaced"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagKeys/{tagKeysId}","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues","path_regex":"^(?:/v3/tagValues)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues/namespaced","path_regex":"^(?:/v3/tagValues/namespaced)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.getNamespaced"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues/{tagValuesId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues/{tagValuesId}/tagHolds","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagHolds)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.tagHolds.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/folders/{foldersId}","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/tagKeys/{tagKeysId}","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/tagValues/{tagValuesId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:clearOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.clearOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:getEffectiveOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectiveOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getEffectiveOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:getOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:listAvailableOrgPolicyConstraints","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAvailableOrgPolicyConstraints)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.listAvailableOrgPolicyConstraints"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:listOrgPolicies","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listOrgPolicies)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.listOrgPolicies"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:setOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/liens","path_regex":"^(?:/v1/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:clearOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.clearOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getEffectiveOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectiveOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getEffectiveOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:listAvailableOrgPolicyConstraints","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAvailableOrgPolicyConstraints)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.listAvailableOrgPolicyConstraints"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:listOrgPolicies","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listOrgPolicies)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.listOrgPolicies"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations:search","path_regex":"^(?:/v1/organizations:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations:search","path_regex":"^(?:/v1/organizations:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:getAncestry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getAncestry)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getAncestry"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:clearOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.clearOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:getEffectiveOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectiveOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getEffectiveOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:getOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:listAvailableOrgPolicyConstraints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAvailableOrgPolicyConstraints)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.listAvailableOrgPolicyConstraints"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:listOrgPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listOrgPolicies)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.listOrgPolicies"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:setOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{resource}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{resource}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{resource}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:getIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:setIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:testIamPermissions","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects","path_regex":"^(?:/v1beta1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:getAncestry","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getAncestry)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getAncestry"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{resource}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{resource}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{resource}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:getIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:getIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:move","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:move","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:setIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:setIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:testIamPermissions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:testIamPermissions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:undelete","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:undelete","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders:search","path_regex":"^(?:/v2/folders:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders:search","path_regex":"^(?:/v2/folders:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders","path_regex":"^(?:/v3/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:getIamPolicy","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:move","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:setIamPolicy","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:testIamPermissions","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:undelete","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/liens","path_regex":"^(?:/v3/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/organizations/{organizationsId}:getIamPolicy","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/organizations/{organizationsId}:setIamPolicy","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/organizations/{organizationsId}:testIamPermissions","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects","path_regex":"^(?:/v3/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:getIamPolicy","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:move","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:setIamPolicy","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:testIamPermissions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:undelete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagBindings","path_regex":"^(?:/v3/tagBindings)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagBindings.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys","path_regex":"^(?:/v3/tagKeys)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys/{tagKeysId}:getIamPolicy","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys/{tagKeysId}:setIamPolicy","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys/{tagKeysId}:testIamPermissions","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues","path_regex":"^(?:/v3/tagValues)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}/tagHolds","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagHolds)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.tagHolds.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}:getIamPolicy","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}:setIamPolicy","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}:testIamPermissions","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.update"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PUT","path_template":"/v1beta1/organizations/{organizationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.update"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.update"},{"hostname":"cloudscheduler.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.delete"},{"hostname":"cloudscheduler.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.delete"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.patch"},{"hostname":"cloudscheduler.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.patch"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.create"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:pause","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.pause"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.resume"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.run"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.create"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:pause","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.pause"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.resume"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:run","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.run"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.delete"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/indexing/datasources/{datasourcesId}/schema","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schema)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.deleteSchema"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.delete"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.delete"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/debug/datasources/{datasourcesId}/items/{itemsId}/unmappedids","path_regex":"^(?:/v1/debug/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unmappedids)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.datasources.items.unmappedids.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/debug/identitysources/{identitysourcesId}/items:forunmappedidentity","path_regex":"^(?:/v1/debug/identitysources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:forunmappedidentity)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.identitysources.items.listForunmappedidentity"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/debug/identitysources/{identitysourcesId}/unmappedids","path_regex":"^(?:/v1/debug/identitysources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unmappedids)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.identitysources.unmappedids.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/indexing/datasources/{datasourcesId}/items","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/indexing/datasources/{datasourcesId}/schema","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schema)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.getSchema"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.operations.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}/lro","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lro)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.operations.lro.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/query/sources","path_regex":"^(?:/v1/query/sources)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.sources.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/customer","path_regex":"^(?:/v1/settings/customer)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.getCustomer"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/datasources","path_regex":"^(?:/v1/settings/datasources)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/searchapplications","path_regex":"^(?:/v1/settings/searchapplications)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/index","path_regex":"^(?:/v1/stats/index)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getIndex"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/index/datasources/{datasourcesId}","path_regex":"^(?:/v1/stats/index/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.index.datasources.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/query","path_regex":"^(?:/v1/stats/query)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getQuery"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/query/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/stats/query/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.query.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/searchapplication","path_regex":"^(?:/v1/stats/searchapplication)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getSearchapplication"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/session","path_regex":"^(?:/v1/stats/session)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getSession"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/session/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/stats/session/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.session.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/user","path_regex":"^(?:/v1/stats/user)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getUser"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/user/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/stats/user/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.user.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"PATCH","path_template":"/v1/settings/customer","path_regex":"^(?:/v1/settings/customer)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.updateCustomer"},{"hostname":"cloudsearch.googleapis.com","http_method":"PATCH","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.patch"},{"hostname":"cloudsearch.googleapis.com","http_method":"PATCH","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.patch"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/debug/datasources/{datasourcesId}/items/{itemsId}:checkAccess","path_regex":"^(?:/v1/debug/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkAccess)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.datasources.items.checkAccess"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/debug/datasources/{datasourcesId}/items:searchByViewUrl","path_regex":"^(?:/v1/debug/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:searchByViewUrl)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.datasources.items.searchByViewUrl"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}:index","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::index)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.index"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}:push","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::push)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.push"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}:upload","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upload)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.upload"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items:deleteQueueItems","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:deleteQueueItems)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.deleteQueueItems"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items:poll","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:poll)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.poll"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items:unreserve","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:unreserve)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.unreserve"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.media.upload"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/query/search","path_regex":"^(?:/v1/query/search)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.search"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/query/suggest","path_regex":"^(?:/v1/query/suggest)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.suggest"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/settings/datasources","path_regex":"^(?:/v1/settings/datasources)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.create"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/settings/searchapplications","path_regex":"^(?:/v1/settings/searchapplications)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.create"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/settings/searchapplications/{searchapplicationsId}:reset","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.reset"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1:initializeCustomer","path_regex":"^(?:/v1:initializeCustomer)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.initializeCustomer"},{"hostname":"cloudsearch.googleapis.com","http_method":"PUT","path_template":"/v1/indexing/datasources/{datasourcesId}/schema","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schema)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.updateSchema"},{"hostname":"cloudsearch.googleapis.com","http_method":"PUT","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.update"},{"hostname":"cloudsearch.googleapis.com","http_method":"PUT","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.update"},{"hostname":"cloudshell.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.delete"},{"hostname":"cloudshell.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}/publicKeys/{publicKeysId}","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.publicKeys.delete"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.list"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.get"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/environments/{environmentsId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.get"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.get"},{"hostname":"cloudshell.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.patch"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.cancel"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:addPublicKey","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addPublicKey)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.addPublicKey"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:authorize","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::authorize)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.authorize"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:removePublicKey","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removePublicKey)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.removePublicKey"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:start","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.start"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}/publicKeys","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicKeys)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.publicKeys.create"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}:authorize","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::authorize)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.authorize"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}:start","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.start"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/caseClassifications:search","path_regex":"^(?:/v2beta/caseClassifications:search)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.caseClassifications.search"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/cases:search","path_regex":"^(?:/v2beta/cases:search)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.search"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.get"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/attachments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.attachments.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/attachments/{attachmentsId}:download","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.media.download"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/comments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.comments.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"PATCH","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.patch"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.create"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/attachments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.media.upload"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/comments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.comments.create"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}:close","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.close"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}:escalate","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::escalate)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.escalate"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.patch"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.patch"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.patch"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/api/queue/update","path_regex":"^(?:/api/queue/update)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.api.queue.update"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:run","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.run"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.getIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:pause","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.pause"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:purge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::purge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.purge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:resume","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.resume"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.setIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.testIamPermissions"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{taskId}:buffer","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::buffer)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.buffer"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:acknowledge","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.acknowledge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:cancelLease","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelLease)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.cancelLease"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:renewLease","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::renewLease)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.renewLease"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:run","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.run"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks:lease","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks:lease)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.lease"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:getIamPolicy","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.getIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:pause","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.pause"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:purge","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::purge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.purge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:resume","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.resume"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:setIamPolicy","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.setIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:testIamPermissions","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.testIamPermissions"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{taskId}:buffer","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::buffer)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.buffer"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:run","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.run"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:getIamPolicy","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.getIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:pause","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.pause"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:purge","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::purge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.purge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:resume","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.resume"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:setIamPolicy","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.setIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:testIamPermissions","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.testIamPermissions"},{"hostname":"cloudtrace.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/traceSinks/{traceSinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.delete"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/traces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.list"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/traces/{traceId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.get"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/traceSinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.list"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/traceSinks/{traceSinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.get"},{"hostname":"cloudtrace.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/traces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.patchTraces"},{"hostname":"cloudtrace.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/traceSinks/{traceSinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.patch"},{"hostname":"cloudtrace.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/traces/{tracesId}/spans/{spansId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.spans.createSpan"},{"hostname":"cloudtrace.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/traces:batchWrite","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces:batchWrite)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.batchWrite"},{"hostname":"cloudtrace.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/traceSinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.create"},{"hostname":"commentanalyzer.googleapis.com","http_method":"POST","path_template":"/v1alpha1/comments:analyze","path_regex":"^(?:/v1alpha1/comments:analyze)$","service_name":"google.commentanalyzer","resource_name":"commentanalyzer.comments.analyze"},{"hostname":"commentanalyzer.googleapis.com","http_method":"POST","path_template":"/v1alpha1/comments:suggestscore","path_regex":"^(?:/v1alpha1/comments:suggestscore)$","service_name":"google.commentanalyzer","resource_name":"commentanalyzer.comments.suggestscore"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.delete"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageVersions)$","service_name":"google.composer","resource_name":"composer.projects.locations.imageVersions.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/imageVersions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageVersions)$","service_name":"google.composer","resource_name":"composer.projects.locations.imageVersions.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.get"},{"hostname":"composer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.patch"},{"hostname":"composer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.patch"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:loadSnapshot","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::loadSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.loadSnapshot"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:saveSnapshot","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::saveSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.saveSnapshot"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:checkUpgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkUpgrade)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.checkUpgrade"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:loadSnapshot","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::loadSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.loadSnapshot"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:restartWebServer","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restartWebServer)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.restartWebServer"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:saveSnapshot","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::saveSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.saveSnapshot"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/locations/global/operations/{operation}","path_regex":"^(?:/compute/alpha/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources/{queuedResource}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/locations/global/operations/{operation}","path_regex":"^(?:/compute/beta/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/locations/global/operations/{operation}","path_regex":"^(?:/compute/v1/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.delete"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/listAssociations","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/operations","path_regex":"^(?:/compute/alpha/locations/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/operations/{operation}","path_regex":"^(?:/compute/alpha/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/listAssociations","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.projects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/acceleratorTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/commitments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/diskTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/disks)$","service_name":"google.compute","resource_name":"compute.disks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/futureReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/healthCheckServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instances)$","service_name":"google.compute","resource_name":"compute.instances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/interconnectAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/machineTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/networkAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/networkEdgeSecurityServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/nodeGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/nodeTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/nodeTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/notificationEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/packetMirrorings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/queuedResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/queuedResources)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/reservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/resourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/routers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/routers)$","service_name":"google.compute","resource_name":"compute.routers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/serviceAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/storagePools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/subnetworks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/subnetworks/listUsable","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks/listUsable)$","service_name":"google.compute","resource_name":"compute.subnetworks.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/vpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/vpnTunnels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/getXpnHost","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.getXpnHost"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/getXpnResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnResources)$","service_name":"google.compute","resource_name":"compute.projects.getXpnResources"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/addresses/getOwnerInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/getOwnerInstance)$","service_name":"google.compute","resource_name":"compute.globalAddresses.getOwnerInstance"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images/family/{family}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/family/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.getFromFamily"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectLocations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectLocations/{interconnectLocation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectRemoteLocations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations)$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectRemoteLocations/{interconnectRemoteLocation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}/getDiagnostics","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiagnostics)$","service_name":"google.compute","resource_name":"compute.interconnects.getDiagnostics"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}/getMacsecConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getMacsecConfig)$","service_name":"google.compute","resource_name":"compute.interconnects.getMacsecConfig"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnects.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{licenseCode}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenseCodes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenseCodes.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenses/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/machineImages","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/machineImages/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/getEffectiveFirewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.networks.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/listIpAddresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listIpAddresses)$","service_name":"google.compute","resource_name":"compute.networks.listIpAddresses"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/listIpOwners","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listIpOwners)$","service_name":"google.compute","resource_name":"compute.networks.listIpOwners"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/listPeeringRoutes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPeeringRoutes)$","service_name":"google.compute","resource_name":"compute.networks.listPeeringRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/routes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/listPreconfiguredExpressionSets","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/listPreconfiguredExpressionSets)$","service_name":"google.compute","resource_name":"compute.securityPolicies.listPreconfiguredExpressionSets"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/snapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.sslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.compute","resource_name":"compute.regions.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regions.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/diskTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/diskTypes/{diskType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/getEffectiveFirewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.regionOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/getNatMappingInfo","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatMappingInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatMappingInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/getRouterStatus","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRouterStatus)$","service_name":"google.compute","resource_name":"compute.routers.getRouterStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}/getStatus","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getStatus)$","service_name":"google.compute","resource_name":"compute.vpnGateways.getStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.zones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zones.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/acceleratorTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/acceleratorTypes/{acceleratorType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/diskTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/diskTypes/{diskType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.diskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/imageFamilyViews/{family}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageFamilyViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.imageFamilyViews.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getEffectiveFirewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.instances.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getGuestAttributes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getGuestAttributes)$","service_name":"google.compute","resource_name":"compute.instances.getGuestAttributes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getShieldedInstanceIdentity","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedInstanceIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedInstanceIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getShieldedVmIdentity","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedVmIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedVmIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/referrers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referrers)$","service_name":"google.compute","resource_name":"compute.instances.listReferrers"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/screenshot","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/screenshot)$","service_name":"google.compute","resource_name":"compute.instances.getScreenshot"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/serialPort","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serialPort)$","service_name":"google.compute","resource_name":"compute.instances.getSerialPortOutput"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/machineTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/machineTypes/{machineType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeTypes/{nodeType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.zoneOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources/{queuedResource}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/listAssociations","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/operations","path_regex":"^(?:/compute/beta/locations/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/operations/{operation}","path_regex":"^(?:/compute/beta/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies","path_regex":"^(?:/compute/beta/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/listAssociations","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/getAssociation","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.projects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/acceleratorTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/commitments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/diskTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/disks)$","service_name":"google.compute","resource_name":"compute.disks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instances)$","service_name":"google.compute","resource_name":"compute.instances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/interconnectAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/machineTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/networkAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/networkEdgeSecurityServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/nodeGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/nodeTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/nodeTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/packetMirrorings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/reservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/resourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/routers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/routers)$","service_name":"google.compute","resource_name":"compute.routers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/serviceAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/subnetworks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/subnetworks/listUsable","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks/listUsable)$","service_name":"google.compute","resource_name":"compute.subnetworks.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/vpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/vpnTunnels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/getXpnHost","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.getXpnHost"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/getXpnResources","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnResources)$","service_name":"google.compute","resource_name":"compute.projects.getXpnResources"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images/family/{family}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/family/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.getFromFamily"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnectLocations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnectLocations/{interconnectLocation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnects","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}/getDiagnostics","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiagnostics)$","service_name":"google.compute","resource_name":"compute.interconnects.getDiagnostics"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenseCodes/{licenseCode}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenseCodes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenses/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/machineImages","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/machineImages/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks/{network}/getEffectiveFirewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.networks.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks/{network}/listPeeringRoutes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPeeringRoutes)$","service_name":"google.compute","resource_name":"compute.networks.listPeeringRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/routes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies/listPreconfiguredExpressionSets","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/listPreconfiguredExpressionSets)$","service_name":"google.compute","resource_name":"compute.securityPolicies.listPreconfiguredExpressionSets"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/snapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.sslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.compute","resource_name":"compute.regions.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regions.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/diskTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/diskTypes/{diskType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/getEffectiveFirewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.regionOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/getNatMappingInfo","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatMappingInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatMappingInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/getRouterStatus","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRouterStatus)$","service_name":"google.compute","resource_name":"compute.routers.getRouterStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}/getStatus","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getStatus)$","service_name":"google.compute","resource_name":"compute.vpnGateways.getStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.zones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zones.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/acceleratorTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/acceleratorTypes/{acceleratorType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/diskTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/diskTypes/{diskType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.diskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/imageFamilyViews/{family}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageFamilyViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.imageFamilyViews.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getEffectiveFirewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.instances.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getGuestAttributes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getGuestAttributes)$","service_name":"google.compute","resource_name":"compute.instances.getGuestAttributes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getShieldedInstanceIdentity","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedInstanceIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedInstanceIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getShieldedVmIdentity","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedVmIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedVmIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/referrers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referrers)$","service_name":"google.compute","resource_name":"compute.instances.listReferrers"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/screenshot","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/screenshot)$","service_name":"google.compute","resource_name":"compute.instances.getScreenshot"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/serialPort","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serialPort)$","service_name":"google.compute","resource_name":"compute.instances.getSerialPortOutput"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/machineTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/machineTypes/{machineType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeTypes/{nodeType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.zoneOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/listAssociations","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/operations","path_regex":"^(?:/compute/v1/locations/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/operations/{operation}","path_regex":"^(?:/compute/v1/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.projects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/acceleratorTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/commitments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/diskTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/disks)$","service_name":"google.compute","resource_name":"compute.disks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instances)$","service_name":"google.compute","resource_name":"compute.instances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/interconnectAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/machineTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/networkAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/networkEdgeSecurityServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/nodeGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/nodeTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/nodeTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/packetMirrorings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/reservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/resourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/routers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/routers)$","service_name":"google.compute","resource_name":"compute.routers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/serviceAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/subnetworks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/subnetworks/listUsable","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks/listUsable)$","service_name":"google.compute","resource_name":"compute.subnetworks.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/vpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/vpnTunnels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/getXpnHost","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.getXpnHost"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/getXpnResources","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnResources)$","service_name":"google.compute","resource_name":"compute.projects.getXpnResources"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images/family/{family}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/family/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.getFromFamily"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnectLocations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnectLocations/{interconnectLocation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnects","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}/getDiagnostics","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiagnostics)$","service_name":"google.compute","resource_name":"compute.interconnects.getDiagnostics"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenseCodes/{licenseCode}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenseCodes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenses/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/machineImages","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/machineImages/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks/{network}/getEffectiveFirewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.networks.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks/{network}/listPeeringRoutes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPeeringRoutes)$","service_name":"google.compute","resource_name":"compute.networks.listPeeringRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/routes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies/listPreconfiguredExpressionSets","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/listPreconfiguredExpressionSets)$","service_name":"google.compute","resource_name":"compute.securityPolicies.listPreconfiguredExpressionSets"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/snapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.sslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.compute","resource_name":"compute.regions.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regions.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/diskTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/diskTypes/{diskType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/getEffectiveFirewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.regionOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}/getNatMappingInfo","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatMappingInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatMappingInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}/getRouterStatus","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRouterStatus)$","service_name":"google.compute","resource_name":"compute.routers.getRouterStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}/getStatus","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getStatus)$","service_name":"google.compute","resource_name":"compute.vpnGateways.getStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.zones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zones.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/acceleratorTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/acceleratorTypes/{acceleratorType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/diskTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/diskTypes/{diskType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.diskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/imageFamilyViews/{family}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageFamilyViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.imageFamilyViews.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/getEffectiveFirewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.instances.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/getGuestAttributes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getGuestAttributes)$","service_name":"google.compute","resource_name":"compute.instances.getGuestAttributes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/getShieldedInstanceIdentity","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedInstanceIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedInstanceIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/referrers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referrers)$","service_name":"google.compute","resource_name":"compute.instances.listReferrers"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/screenshot","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/screenshot)$","service_name":"google.compute","resource_name":"compute.instances.getScreenshot"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/serialPort","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serialPort)$","service_name":"google.compute","resource_name":"compute.instances.getSerialPortOutput"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/machineTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/machineTypes/{machineType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeTypes/{nodeType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.zoneOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.get"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/updatePeering","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePeering)$","service_name":"google.compute","resource_name":"compute.networks.updatePeering"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setShieldedInstanceIntegrityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedInstanceIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedInstanceIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setShieldedVmIntegrityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedVmIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedVmIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateDisplayDevice","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateDisplayDevice)$","service_name":"google.compute","resource_name":"compute.instances.updateDisplayDevice"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateNetworkInterface","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.updateNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedInstanceConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedInstanceConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedInstanceConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedVmConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedVmConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedVmConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/networks/{network}/updatePeering","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePeering)$","service_name":"google.compute","resource_name":"compute.networks.updatePeering"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setShieldedInstanceIntegrityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedInstanceIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedInstanceIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setShieldedVmIntegrityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedVmIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedVmIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateDisplayDevice","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateDisplayDevice)$","service_name":"google.compute","resource_name":"compute.instances.updateDisplayDevice"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateNetworkInterface","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.updateNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedInstanceConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedInstanceConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedInstanceConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedVmConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedVmConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedVmConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/networks/{network}/updatePeering","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePeering)$","service_name":"google.compute","resource_name":"compute.networks.updatePeering"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setShieldedInstanceIntegrityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedInstanceIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedInstanceIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateDisplayDevice","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateDisplayDevice)$","service_name":"google.compute","resource_name":"compute.instances.updateDisplayDevice"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateNetworkInterface","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.updateNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedInstanceConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedInstanceConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedInstanceConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.update"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/move","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/copyRules","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyRules)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.copyRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/move","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/disableXpnHost","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/disableXpnResource","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/enableXpnHost","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/enableXpnResource","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses/{address}/move","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.globalAddresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalAddresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalAddresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}/addSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}/deleteSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendBuckets.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/addSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/deleteSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.backendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewalls/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewalls.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.healthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{image}/deprecate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deprecate)$","service_name":"google.compute","resource_name":"compute.images.deprecate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.images.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.images.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnectLocations/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnectRemoteLocations/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnects.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnects.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnects.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenseCodes.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenseCodes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenses/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenses/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/machineImages","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/machineImages/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/machineImages/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.machineImages.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/addPeering","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPeering)$","service_name":"google.compute","resource_name":"compute.networks.addPeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/removePeering","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePeering)$","service_name":"google.compute","resource_name":"compute.networks.removePeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/switchToCustomMode","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchToCustomMode)$","service_name":"google.compute","resource_name":"compute.networks.switchToCustomMode"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/operations/{operation}/wait","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.globalOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/announce","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/withdraw","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/routes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/routes/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.securityPolicies.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.securityPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.snapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.snapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setCertificateMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setQuicOverride","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setQuicOverride)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setQuicOverride"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setSslPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setBackendService","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setCertificateMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setProxyHeader","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setBackendService","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setProxyHeader","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.urlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.urlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.urlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/listXpnHosts","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listXpnHosts)$","service_name":"google.compute","resource_name":"compute.projects.listXpnHosts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/moveDisk","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveDisk)$","service_name":"google.compute","resource_name":"compute.projects.moveDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/moveInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveInstance)$","service_name":"google.compute","resource_name":"compute.projects.moveInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{address}/move","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.addresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.addresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.addresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}/updateReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateReservations)$","service_name":"google.compute","resource_name":"compute.regionCommitments.updateReservations"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionCommitments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionDisks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.regionDisks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionDisks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionDisks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionDisks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.forwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resumeInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resumeInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resumeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/startInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.startInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/stopInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.stopInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/suspendInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspendInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.suspendInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instances/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionInstances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}/export","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.export"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations/{operation}/wait","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.regionOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/announce","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/withdraw","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/preview","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preview)$","service_name":"google.compute","resource_name":"compute.routers.preview"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.subnetworks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}/expandIpCidrRange","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandIpCidrRange)$","service_name":"google.compute","resource_name":"compute.subnetworks.expandIpCidrRange"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}/setPrivateIpGoogleAccess","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPrivateIpGoogleAccess)$","service_name":"google.compute","resource_name":"compute.subnetworks.setPrivateIpGoogleAccess"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetPools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/addHealthCheck","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.addHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/addInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.addInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/getHealth","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.targetPools.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/removeHealthCheck","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.removeHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/removeInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.removeInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/setBackup","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackup)$","service_name":"google.compute","resource_name":"compute.targetPools.setBackup"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetPools.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setCommonInstanceMetadata","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCommonInstanceMetadata)$","service_name":"google.compute","resource_name":"compute.projects.setCommonInstanceMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setDefaultNetworkTier","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultNetworkTier)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultNetworkTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setDefaultServiceAccount","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultServiceAccount)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setUsageExportBucket","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUsageExportBucket)$","service_name":"google.compute","resource_name":"compute.projects.setUsageExportBucket"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.autoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.disks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.disks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.disks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.disks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.disks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}/cancel","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.futureReservations.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}/cancel","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resumeInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resumeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resumeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/startInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.startInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/stopInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.stopInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/suspendInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspendInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.suspendInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/addInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.addInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/removeInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.removeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.instanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.instances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/addAccessConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.addAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/addResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/attachDisk","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachDisk)$","service_name":"google.compute","resource_name":"compute.instances.attachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/deleteAccessConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.deleteAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/detachDisk","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachDisk)$","service_name":"google.compute","resource_name":"compute.instances.detachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/performMaintenance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.instances.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/removeResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/reset","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.compute","resource_name":"compute.instances.reset"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/resume","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.compute","resource_name":"compute.instances.resume"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/sendDiagnosticInterrupt","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendDiagnosticInterrupt)$","service_name":"google.compute","resource_name":"compute.instances.sendDiagnosticInterrupt"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setDiskAutoDelete","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDiskAutoDelete)$","service_name":"google.compute","resource_name":"compute.instances.setDiskAutoDelete"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instances.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMachineResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineResources)$","service_name":"google.compute","resource_name":"compute.instances.setMachineResources"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMachineType","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineType)$","service_name":"google.compute","resource_name":"compute.instances.setMachineType"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMetadata","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMetadata)$","service_name":"google.compute","resource_name":"compute.instances.setMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMinCpuPlatform","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMinCpuPlatform)$","service_name":"google.compute","resource_name":"compute.instances.setMinCpuPlatform"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setName","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setName)$","service_name":"google.compute","resource_name":"compute.instances.setName"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setScheduling","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setScheduling)$","service_name":"google.compute","resource_name":"compute.instances.setScheduling"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setServiceAccount","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setServiceAccount)$","service_name":"google.compute","resource_name":"compute.instances.setServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setTags","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTags)$","service_name":"google.compute","resource_name":"compute.instances.setTags"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/simulateMaintenanceEvent","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.instances.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/start","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.compute","resource_name":"compute.instances.start"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/startWithEncryptionKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startWithEncryptionKey)$","service_name":"google.compute","resource_name":"compute.instances.startWithEncryptionKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/stop","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.compute","resource_name":"compute.instances.stop"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/suspend","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.compute","resource_name":"compute.instances.suspend"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateAccessConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/setDeletionProtection","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDeletionProtection)$","service_name":"google.compute","resource_name":"compute.instances.setDeletionProtection"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}/export","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.export"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/addNodes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.addNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/deleteNodes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.deleteNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/listNodes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.listNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/performMaintenance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.nodeGroups.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/setNodeTemplate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNodeTemplate)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setNodeTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/simulateMaintenanceEvent","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.nodeGroups.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations/{operation}/wait","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.zoneOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources/{queuedResource}/cancel","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.reservations.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.reservations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.storagePools.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.storagePools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetInstances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{targetInstance}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetInstances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/move","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies","path_regex":"^(?:/compute/beta/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/addAssociation","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/copyRules","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyRules)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.copyRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/move","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/disableXpnHost","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/disableXpnResource","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/enableXpnHost","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/enableXpnResource","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses/{address}/move","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.globalAddresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalAddresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalAddresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}/addSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}/deleteSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendBuckets.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/addSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/deleteSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.backendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewalls/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewalls.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.healthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{image}/deprecate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deprecate)$","service_name":"google.compute","resource_name":"compute.images.deprecate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.images.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.images.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/interconnects","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/interconnects/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnects.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/interconnects/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnects.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenseCodes/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenseCodes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenses/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenses/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/machineImages","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/machineImages/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/machineImages/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.machineImages.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{network}/addPeering","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPeering)$","service_name":"google.compute","resource_name":"compute.networks.addPeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{network}/removePeering","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePeering)$","service_name":"google.compute","resource_name":"compute.networks.removePeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{network}/switchToCustomMode","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchToCustomMode)$","service_name":"google.compute","resource_name":"compute.networks.switchToCustomMode"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/operations/{operation}/wait","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.globalOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/routes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/routes/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.securityPolicies.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.securityPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.snapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.snapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setCertificateMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setQuicOverride","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setQuicOverride)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setQuicOverride"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setSslPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setBackendService","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setCertificateMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setProxyHeader","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setBackendService","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setProxyHeader","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.urlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.urlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.urlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/listXpnHosts","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listXpnHosts)$","service_name":"google.compute","resource_name":"compute.projects.listXpnHosts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/moveDisk","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveDisk)$","service_name":"google.compute","resource_name":"compute.projects.moveDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/moveInstance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveInstance)$","service_name":"google.compute","resource_name":"compute.projects.moveInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{address}/move","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.addresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.addresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.addresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{commitment}/updateReservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateReservations)$","service_name":"google.compute","resource_name":"compute.regionCommitments.updateReservations"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionCommitments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionDisks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.regionDisks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionDisks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionDisks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionDisks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.forwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instances/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionInstances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/operations/{operation}/wait","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.regionOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/preview","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preview)$","service_name":"google.compute","resource_name":"compute.routers.preview"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.subnetworks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}/expandIpCidrRange","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandIpCidrRange)$","service_name":"google.compute","resource_name":"compute.subnetworks.expandIpCidrRange"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}/setPrivateIpGoogleAccess","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPrivateIpGoogleAccess)$","service_name":"google.compute","resource_name":"compute.subnetworks.setPrivateIpGoogleAccess"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetPools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/addHealthCheck","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.addHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/addInstance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.addInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/getHealth","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.targetPools.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/removeHealthCheck","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.removeHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/removeInstance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.removeInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/setBackup","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackup)$","service_name":"google.compute","resource_name":"compute.targetPools.setBackup"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setCommonInstanceMetadata","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCommonInstanceMetadata)$","service_name":"google.compute","resource_name":"compute.projects.setCommonInstanceMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setDefaultNetworkTier","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultNetworkTier)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultNetworkTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setUsageExportBucket","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUsageExportBucket)$","service_name":"google.compute","resource_name":"compute.projects.setUsageExportBucket"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.autoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.disks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.disks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.disks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.disks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.disks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/addInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.addInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/removeInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.removeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.instanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.instances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/addAccessConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.addAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/addResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/attachDisk","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachDisk)$","service_name":"google.compute","resource_name":"compute.instances.attachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/deleteAccessConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.deleteAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/detachDisk","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachDisk)$","service_name":"google.compute","resource_name":"compute.instances.detachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/removeResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/reset","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.compute","resource_name":"compute.instances.reset"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/resume","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.compute","resource_name":"compute.instances.resume"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/sendDiagnosticInterrupt","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendDiagnosticInterrupt)$","service_name":"google.compute","resource_name":"compute.instances.sendDiagnosticInterrupt"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setDiskAutoDelete","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDiskAutoDelete)$","service_name":"google.compute","resource_name":"compute.instances.setDiskAutoDelete"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instances.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMachineResources","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineResources)$","service_name":"google.compute","resource_name":"compute.instances.setMachineResources"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMachineType","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineType)$","service_name":"google.compute","resource_name":"compute.instances.setMachineType"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMetadata","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMetadata)$","service_name":"google.compute","resource_name":"compute.instances.setMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMinCpuPlatform","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMinCpuPlatform)$","service_name":"google.compute","resource_name":"compute.instances.setMinCpuPlatform"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setName","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setName)$","service_name":"google.compute","resource_name":"compute.instances.setName"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setScheduling","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setScheduling)$","service_name":"google.compute","resource_name":"compute.instances.setScheduling"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setServiceAccount","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setServiceAccount)$","service_name":"google.compute","resource_name":"compute.instances.setServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setTags","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTags)$","service_name":"google.compute","resource_name":"compute.instances.setTags"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/simulateMaintenanceEvent","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.instances.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/start","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.compute","resource_name":"compute.instances.start"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/startWithEncryptionKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startWithEncryptionKey)$","service_name":"google.compute","resource_name":"compute.instances.startWithEncryptionKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/stop","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.compute","resource_name":"compute.instances.stop"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/suspend","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.compute","resource_name":"compute.instances.suspend"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateAccessConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/setDeletionProtection","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDeletionProtection)$","service_name":"google.compute","resource_name":"compute.instances.setDeletionProtection"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/addNodes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.addNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/deleteNodes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.deleteNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/listNodes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.listNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/setNodeTemplate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNodeTemplate)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setNodeTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/simulateMaintenanceEvent","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.nodeGroups.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations/{operation}/wait","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.zoneOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.reservations.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.reservations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetInstances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/move","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/disableXpnHost","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/disableXpnResource","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/enableXpnHost","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/enableXpnResource","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/addresses/{address}/move","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.globalAddresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/addresses/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalAddresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}/addSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}/deleteSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/addSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/deleteSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.backendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{image}/deprecate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deprecate)$","service_name":"google.compute","resource_name":"compute.images.deprecate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.images.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.images.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/interconnects","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/interconnects/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnects.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenseCodes/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenseCodes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenses/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenses/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/machineImages","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/machineImages/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/machineImages/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.machineImages.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks/{network}/addPeering","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPeering)$","service_name":"google.compute","resource_name":"compute.networks.addPeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks/{network}/removePeering","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePeering)$","service_name":"google.compute","resource_name":"compute.networks.removePeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks/{network}/switchToCustomMode","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchToCustomMode)$","service_name":"google.compute","resource_name":"compute.networks.switchToCustomMode"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/operations/{operation}/wait","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.globalOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/routes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.securityPolicies.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.snapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.snapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setCertificateMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setQuicOverride","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setQuicOverride)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setQuicOverride"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setSslPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setBackendService","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setCertificateMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setProxyHeader","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setBackendService","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setProxyHeader","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.urlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.urlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/listXpnHosts","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listXpnHosts)$","service_name":"google.compute","resource_name":"compute.projects.listXpnHosts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/moveDisk","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveDisk)$","service_name":"google.compute","resource_name":"compute.projects.moveDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/moveInstance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveInstance)$","service_name":"google.compute","resource_name":"compute.projects.moveInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{address}/move","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.addresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.addresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.regionDisks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionDisks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionDisks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionDisks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instances/bulkInsert","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionInstances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/operations/{operation}/wait","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.regionOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}/preview","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preview)$","service_name":"google.compute","resource_name":"compute.routers.preview"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.subnetworks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}/expandIpCidrRange","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandIpCidrRange)$","service_name":"google.compute","resource_name":"compute.subnetworks.expandIpCidrRange"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}/setPrivateIpGoogleAccess","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPrivateIpGoogleAccess)$","service_name":"google.compute","resource_name":"compute.subnetworks.setPrivateIpGoogleAccess"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/addHealthCheck","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.addHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/addInstance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.addInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/getHealth","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.targetPools.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/removeHealthCheck","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.removeHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/removeInstance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.removeInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/setBackup","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackup)$","service_name":"google.compute","resource_name":"compute.targetPools.setBackup"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/setCommonInstanceMetadata","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCommonInstanceMetadata)$","service_name":"google.compute","resource_name":"compute.projects.setCommonInstanceMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/setDefaultNetworkTier","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultNetworkTier)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultNetworkTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/setUsageExportBucket","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUsageExportBucket)$","service_name":"google.compute","resource_name":"compute.projects.setUsageExportBucket"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.disks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.disks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.disks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.disks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/addInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.addInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/removeInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.removeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.instanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/bulkInsert","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.instances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/addAccessConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.addAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/addResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/attachDisk","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachDisk)$","service_name":"google.compute","resource_name":"compute.instances.attachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/deleteAccessConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.deleteAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/detachDisk","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachDisk)$","service_name":"google.compute","resource_name":"compute.instances.detachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/removeResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/reset","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.compute","resource_name":"compute.instances.reset"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/resume","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.compute","resource_name":"compute.instances.resume"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/sendDiagnosticInterrupt","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendDiagnosticInterrupt)$","service_name":"google.compute","resource_name":"compute.instances.sendDiagnosticInterrupt"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setDiskAutoDelete","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDiskAutoDelete)$","service_name":"google.compute","resource_name":"compute.instances.setDiskAutoDelete"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instances.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMachineResources","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineResources)$","service_name":"google.compute","resource_name":"compute.instances.setMachineResources"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMachineType","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineType)$","service_name":"google.compute","resource_name":"compute.instances.setMachineType"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMetadata","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMetadata)$","service_name":"google.compute","resource_name":"compute.instances.setMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMinCpuPlatform","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMinCpuPlatform)$","service_name":"google.compute","resource_name":"compute.instances.setMinCpuPlatform"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setName","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setName)$","service_name":"google.compute","resource_name":"compute.instances.setName"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setScheduling","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setScheduling)$","service_name":"google.compute","resource_name":"compute.instances.setScheduling"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setServiceAccount","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setServiceAccount)$","service_name":"google.compute","resource_name":"compute.instances.setServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setTags","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTags)$","service_name":"google.compute","resource_name":"compute.instances.setTags"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/simulateMaintenanceEvent","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.instances.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/start","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.compute","resource_name":"compute.instances.start"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/startWithEncryptionKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startWithEncryptionKey)$","service_name":"google.compute","resource_name":"compute.instances.startWithEncryptionKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/stop","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.compute","resource_name":"compute.instances.stop"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/suspend","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.compute","resource_name":"compute.instances.suspend"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateAccessConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/setDeletionProtection","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDeletionProtection)$","service_name":"google.compute","resource_name":"compute.instances.setDeletionProtection"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/addNodes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.addNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/deleteNodes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.deleteNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/listNodes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.listNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/setNodeTemplate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNodeTemplate)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setNodeTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/simulateMaintenanceEvent","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.nodeGroups.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations/{operation}/wait","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.zoneOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.reservations.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.reservations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.insert"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.update"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities/{entitiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.delete"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/settings)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.getSettings"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.getConnectionSchemaMetadata"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeActionSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeActionSchemas)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.runtimeActionSchemas.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeEntitySchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeEntitySchemas)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.runtimeEntitySchemas.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.getIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.versions.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.versions.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.getIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimeConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeConfig)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.getRuntimeConfig"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/actions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.actions.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities/{entitiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.get"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.patch"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities/{entitiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.patch"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata:refresh","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata:refresh)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.connectionSchemaMetadata.refresh"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.setIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.testIamPermissions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.cancel"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.setIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.testIamPermissions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/actions/{actionsId}:execute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.actions.execute"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities:deleteEntitiesWithConditions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:deleteEntitiesWithConditions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.deleteEntitiesWithConditions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities:updateEntitiesWithConditions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:updateEntitiesWithConditions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.updateEntitiesWithConditions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:executeSqlQuery","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeSqlQuery)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.executeSqlQuery"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters/{contactCentersId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.delete"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.delete"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.list"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.get"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.list"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters/{contactCentersId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.get"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.list"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.get"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}:queryContactCenterQuota","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryContactCenterQuota)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.queryContactCenterQuota"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters/{contactCentersId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.patch"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.create"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.cancel"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses/{analysesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues/{issuesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers/{phraseMatchersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views/{viewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses/{analysesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:calculateStats","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:calculateStats)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.calculateStats"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues/{issuesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}:calculateIssueModelStats","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::calculateIssueModelStats)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.calculateIssueModelStats"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.operations.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.operations.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers/{phraseMatchersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.getSettings"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views/{viewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues/{issuesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers/{phraseMatchersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.updateSettings"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views/{viewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:bulkAnalyze","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:bulkAnalyze)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.bulkAnalyze"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:ingest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:ingest)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.ingest"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:upload)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.upload"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightsdata:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightsdata:export)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.insightsdata.export"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}:deploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.deploy"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}:undeploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.undeploy"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.operations.cancel"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.create"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.zones.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/operations/{operationId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/serverconfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverconfig)$","service_name":"google.container","resource_name":"container.projects.zones.getServerconfig"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/aggregated/usableSubnetworks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/usableSubnetworks)$","service_name":"google.container","resource_name":"container.projects.aggregated.usableSubnetworks.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/.well-known/openid-configuration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\.well-known/openid-configuration)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.well-known.getOpenid-configuration"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/jwks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jwks)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.getJwks"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.locations.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverConfig)$","service_name":"google.container","resource_name":"container.projects.locations.getServerConfig"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.zones.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/operations/{operationId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/serverconfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverconfig)$","service_name":"google.container","resource_name":"container.projects.zones.getServerconfig"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/aggregated/usableSubnetworks","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/usableSubnetworks)$","service_name":"google.container","resource_name":"container.projects.aggregated.usableSubnetworks.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.container","resource_name":"container.projects.locations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/.well-known/openid-configuration","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\.well-known/openid-configuration)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.well-known.getOpenid-configuration"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/jwks","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jwks)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.getJwks"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.locations.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverConfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverConfig)$","service_name":"google.container","resource_name":"container.projects.locations.getServerConfig"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/addons","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addons)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.addons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/legacyAbac","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/legacyAbac)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.legacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.locations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/logging","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logging)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.logging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/master","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/master)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.master"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/monitoring","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoring)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.monitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/autoscaling","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscaling)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.autoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setManagement","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setManagement)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setSize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSize)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/update","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/update)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.update"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/resourceLabels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceLabels)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.resourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:completeIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMaintenancePolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMasterAuth","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setNetworkPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:startIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/operations/{operationId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.zones.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:completeUpgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeUpgrade)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.completeUpgrade"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setAutoscaling","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAutoscaling)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setAutoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setManagement","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setManagement)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setSize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSize)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:completeIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setAddons","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAddons)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setAddons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLegacyAbac","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLegacyAbac)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLegacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLocations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLocations)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLocations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLogging","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLogging)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLogging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMaintenancePolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMasterAuth","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMonitoring","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMonitoring)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMonitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setNetworkPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setResourceLabels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setResourceLabels)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setResourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:startIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:updateMaster","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateMaster)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.updateMaster"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.locations.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/addons","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addons)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.addons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/legacyAbac","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/legacyAbac)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.legacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.locations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/logging","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logging)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.logging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/master","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/master)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.master"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/monitoring","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoring)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.monitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/autoscaling","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscaling)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.autoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setManagement","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setManagement)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setSize","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSize)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/update","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/update)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.update"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/resourceLabels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceLabels)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.resourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:completeIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMaintenancePolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMasterAuth","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setNetworkPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:startIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/operations/{operationId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.zones.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:completeUpgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeUpgrade)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.completeUpgrade"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setAutoscaling","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAutoscaling)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setAutoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setManagement","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setManagement)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setSize","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSize)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:completeIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setAddons","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAddons)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setAddons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLegacyAbac","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLegacyAbac)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLegacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLocations)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLocations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLogging","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLogging)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLogging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMaintenancePolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMasterAuth","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMonitoring","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMonitoring)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMonitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setNetworkPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setResourceLabels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setResourceLabels)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setResourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:startIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:updateMaster","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateMaster)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.updateMaster"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.locations.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.update"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/notes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.scanConfigs.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.scanConfigs.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/providers/{providersId}/notes","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.operations.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.scanConfigs.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/resources/{resourcesId}:generatePackagesSummary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generatePackagesSummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.resources.generatePackagesSummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.operations.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.batchCreate"},{"hostname":"contentwarehouse.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas/{documentSchemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets/{ruleSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets/{synonymSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.list"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas/{documentSchemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.operations.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.list"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets/{ruleSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.list"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets/{synonymSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas/{documentSchemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/referenceId/{referenceIdId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/referenceId/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.referenceId.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets/{ruleSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets/{synonymSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/referenceId/{referenceIdId}:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/referenceId/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delete)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.referenceId.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/referenceId/{referenceIdId}:get","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/referenceId/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::get)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.referenceId.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/documentLinks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentLinks)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.documentLinks.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/documentLinks/{documentLinksId}:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delete)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.documentLinks.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/linkedSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/linkedSources)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.linkedSources"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/linkedTargets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/linkedTargets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.linkedTargets"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delete)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:fetchAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.fetchAcl"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:get","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::get)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:lock","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lock)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.lock"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:setAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.setAcl"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:search)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.search"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:initialize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initialize)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.initialize"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:fetchAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.fetchAcl"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:setAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.setAcl"},{"hostname":"customsearch.googleapis.com","http_method":"GET","path_template":"/customsearch/v1","path_regex":"^(?:/customsearch/v1)$","service_name":"google.customsearch","resource_name":"search.cse.list"},{"hostname":"customsearch.googleapis.com","http_method":"GET","path_template":"/customsearch/v1/siterestrict","path_regex":"^(?:/customsearch/v1/siterestrict)$","service_name":"google.customsearch","resource_name":"search.cse.siterestrict.list"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/entries:lookup","path_regex":"^(?:/v1/entries:lookup)$","service_name":"google.datacatalog","resource_name":"datacatalog.entries.lookup"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:export)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.export"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/entries:lookup","path_regex":"^(?:/v1beta1/entries:lookup)$","service_name":"google.datacatalog","resource_name":"datacatalog.entries.lookup"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:export)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.export"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/catalog:search","path_regex":"^(?:/v1/catalog:search)$","service_name":"google.datacatalog","resource_name":"datacatalog.catalog.search"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags:reconcile","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags:reconcile)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.reconcile"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:modifyEntryContacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyEntryContacts)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.modifyEntryContacts"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:modifyEntryOverview","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyEntryOverview)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.modifyEntryOverview"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:star","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::star)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.star"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:unstar","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unstar)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.unstar"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries:import)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.import"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.cancel"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}/enumValues/{enumValuesId}:rename","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enumValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.enumValues.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}:rename","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:replace","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::replace)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.replace"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:import)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.import"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalog:search","path_regex":"^(?:/v1beta1/catalog:search)$","service_name":"google.datacatalog","resource_name":"datacatalog.catalog.search"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}/enumValues/{enumValuesId}:rename","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enumValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.enumValues.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}:rename","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:import)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.import"},{"hostname":"dataflow.googleapis.com","http_method":"DELETE","path_template":"/v1b3/projects/{projectId}/locations/{location}/snapshots/{snapshotId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.snapshots.delete"},{"hostname":"dataflow.googleapis.com","http_method":"DELETE","path_template":"/v1b3/projects/{projectId}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.deleteSnapshots"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/messages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.messages.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/metrics","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.getMetrics"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs:aggregated","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:aggregated)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.aggregated"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/executionDetails","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionDetails)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.getExecutionDetails"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/messages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.messages.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/metrics","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.getMetrics"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.snapshots.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/stages/{stageId}/executionDetails","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionDetails)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.stages.getExecutionDetails"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.snapshots.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/snapshots/{snapshotId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.snapshots.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/templates:get","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:get)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.templates.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.snapshots.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/snapshots/{snapshotId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.snapshots.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/templates:get","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:get)$","service_name":"google.dataflow","resource_name":"dataflow.projects.templates.get"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/WorkerMessages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/WorkerMessages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.workerMessages"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/debug/getConfig","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/getConfig)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.debug.getConfig"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/debug/sendCapture","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/sendCapture)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.debug.sendCapture"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/workItems:lease","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:lease)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.workItems.lease"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/workItems:reportStatus","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:reportStatus)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.workItems.reportStatus"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}:snapshot","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::snapshot)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.snapshot"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/WorkerMessages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/WorkerMessages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.workerMessages"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/flexTemplates:launch","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flexTemplates:launch)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.flexTemplates.launch"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/debug/getConfig","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/getConfig)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.debug.getConfig"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/debug/sendCapture","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/sendCapture)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.debug.sendCapture"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/workItems:lease","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:lease)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.workItems.lease"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/workItems:reportStatus","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:reportStatus)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.workItems.reportStatus"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}:snapshot","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::snapshot)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.snapshot"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/templates","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.templates.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/templates:launch","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:launch)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.templates.launch"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/templates","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.dataflow","resource_name":"dataflow.projects.templates.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/templates:launch","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:launch)$","service_name":"google.dataflow","resource_name":"dataflow.projects.templates.launch"},{"hostname":"dataflow.googleapis.com","http_method":"PUT","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.update"},{"hostname":"dataflow.googleapis.com","http_method":"PUT","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.update"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs/{releaseConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs/{workflowConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.delete"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults/{compilationResultsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults/{compilationResultsId}:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::query)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.query"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs/{releaseConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs/{workflowConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::query)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.query"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:fetchFileDiff","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchFileDiff)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.fetchFileDiff"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:fetchFileGitStatuses","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchFileGitStatuses)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.fetchFileGitStatuses"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:fetchGitAheadBehind","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchGitAheadBehind)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.fetchGitAheadBehind"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.getIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:queryDirectoryContents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryDirectoryContents)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.queryDirectoryContents"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:readFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.readFile"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:fetchRemoteBranches","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchRemoteBranches)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.fetchRemoteBranches"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.getIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.patch"},{"hostname":"dataform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs/{releaseConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.patch"},{"hostname":"dataform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs/{workflowConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.patch"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.cancel"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:commit","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.commit"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:installNpmPackages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::installNpmPackages)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.installNpmPackages"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:makeDirectory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::makeDirectory)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.makeDirectory"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:moveDirectory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveDirectory)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.moveDirectory"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:moveFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.moveFile"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:pull","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pull)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.pull"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:push","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::push)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.push"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:removeDirectory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeDirectory)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.removeDirectory"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:removeFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.removeFile"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:reset","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.reset"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.setIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.testIamPermissions"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:writeFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::writeFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.writeFile"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.setIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings/{dnsPeeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings/{dnsPeeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.delete"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.getIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.versions.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces/{namespacesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.getIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.getIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.versions.list"},{"hostname":"datafusion.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.patch"},{"hostname":"datafusion.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.patch"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.restart"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.setIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.cancel"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces/{namespacesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.setIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces/{namespacesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restart","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.restart"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.setIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.upgrade"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.cancel"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/{locationsId1}:removeIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.removeIamPolicy"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets/{annotationSpecSetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages/{feedbackMessagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/instructions/{instructionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets/{annotationSpecSetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/dataItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.dataItems.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/dataItems/{dataItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.dataItems.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/examples","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.examples.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/examples/{examplesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.examples.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages/{feedbackMessagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/dataItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.dataItems.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/dataItems/{dataItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.dataItems.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.evaluations.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/evaluations:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations:search)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluations.search"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/instructions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/instructions/{instructionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.cancel"},{"hostname":"datalabeling.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.patch"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/evaluations/{evaluationsId}/exampleComparisons:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exampleComparisons:search)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.evaluations.exampleComparisons.search"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/image:label","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/image:label)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.image.label"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/text:label","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/text:label)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.text.label"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/video:label","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/video:label)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.video.label"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}:exportData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportData)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.exportData"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}:importData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importData)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.importData"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}:pause","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.pause"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.resume"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/instructions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.create"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.delete"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.delete"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.delete"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents/{lineageEventsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.delete"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.get"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.get"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.get"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents/{lineageEventsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.get"},{"hostname":"datalineage.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.patch"},{"hostname":"datalineage.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.patch"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.cancel"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.create"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.create"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.create"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:batchSearchLinkProcesses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchSearchLinkProcesses)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.batchSearchLinkProcesses"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:searchLinks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchLinks)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.searchLinks"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.delete"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:describeConversionWorkspaceRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::describeConversionWorkspaceRevisions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.describeConversionWorkspaceRevisions"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:describeDatabaseEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::describeDatabaseEntities)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.describeDatabaseEntities"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:searchBackgroundJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchBackgroundJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.searchBackgroundJobs"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:fetchStaticIps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchStaticIps)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.fetchStaticIps"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.get"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.patch"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}/mappingRules:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mappingRules:import)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.mappingRules.import"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:apply","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::apply)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.apply"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.commit"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:convert","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::convert)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.convert"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.rollback"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:seed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::seed)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.seed"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:generateSshScript","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateSshScript)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.generateSshScript"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:promote","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promote)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.promote"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.restart"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.resume"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.start"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.stop"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:verify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.verify"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.cancel"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:generateSshScript","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateSshScript)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.generateSshScript"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:promote","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promote)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.promote"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:restart","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.restart"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.resume"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:start","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.start"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:stop","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.stop"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:verify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.verify"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.cancel"},{"hostname":"datapipelines.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.delete"},{"hostname":"datapipelines.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.list"},{"hostname":"datapipelines.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.get"},{"hostname":"datapipelines.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.jobs.list"},{"hostname":"datapipelines.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.patch"},{"hostname":"datapipelines.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.create"},{"hostname":"datapipelines.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.run"},{"hostname":"datapipelines.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.stop"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions/{partitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.delete"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.jobs.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.jobs.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/actions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.actions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.sessions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.jobs.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.jobs.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/actions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.actions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}/actions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.actions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions/{partitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.get"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.patch"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.run"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}/jobs/{jobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.jobs.cancel"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.run"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.cancel"},{"hostname":"dataplex.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.update"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches/{batchesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches/{batchesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}/nodeGroups/{nodeGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.nodeGroups.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.patch"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.patch"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.patch"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.patch"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:diagnose","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.diagnose"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:repair","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.repair"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.start"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.stop"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/jobs:submit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submit)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submit"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/jobs:submitAsOperation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submitAsOperation)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submitAsOperation"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}/nodeGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.nodeGroups.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}/nodeGroups/{nodeGroupsId}:resize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resize)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.nodeGroups.resize"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:injectCredentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::injectCredentials)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.injectCredentials"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}:diagnose","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.diagnose"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}:start","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.start"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}:stop","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.stop"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}:cancel","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs:submit","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submit)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submit"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs:submitAsOperation","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submitAsOperation)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submitAsOperation"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:injectCredentials","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::injectCredentials)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.injectCredentials"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.update"},{"hostname":"datastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/indexes/{indexId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.delete"},{"hostname":"datastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.operations.delete"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.list"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/indexes/{indexId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.get"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datastore","resource_name":"datastore.projects.operations.list"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.operations.get"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.create"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:allocateIds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::allocateIds)$","service_name":"google.datastore","resource_name":"datastore.projects.allocateIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:beginTransaction","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::beginTransaction)$","service_name":"google.datastore","resource_name":"datastore.projects.beginTransaction"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.datastore","resource_name":"datastore.projects.commit"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.datastore","resource_name":"datastore.projects.export"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.datastore","resource_name":"datastore.projects.import"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookup)$","service_name":"google.datastore","resource_name":"datastore.projects.lookup"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:reserveIds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reserveIds)$","service_name":"google.datastore","resource_name":"datastore.projects.reserveIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.datastore","resource_name":"datastore.projects.rollback"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:runAggregationQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runAggregationQuery"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:runQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runQuery"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datastore","resource_name":"datastore.projects.operations.cancel"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.datastore","resource_name":"datastore.projects.export"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.datastore","resource_name":"datastore.projects.import"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:allocateIds","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::allocateIds)$","service_name":"google.datastore","resource_name":"datastore.projects.allocateIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:beginTransaction","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::beginTransaction)$","service_name":"google.datastore","resource_name":"datastore.projects.beginTransaction"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:commit","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.datastore","resource_name":"datastore.projects.commit"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:lookup","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookup)$","service_name":"google.datastore","resource_name":"datastore.projects.lookup"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:reserveIds","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reserveIds)$","service_name":"google.datastore","resource_name":"datastore.projects.reserveIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:rollback","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.datastore","resource_name":"datastore.projects.rollback"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:runAggregationQuery","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runAggregationQuery"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:runQuery","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runQuery"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.delete"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:fetchStaticIps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchStaticIps)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.fetchStaticIps"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}:fetchStaticIps","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchStaticIps)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.fetchStaticIps"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.patch"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.patch"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.patch"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.patch"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles:discover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles:discover)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.discover"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.cancel"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:startBackfillJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.startBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:stopBackfillJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.stopBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects:lookup)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.lookup"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles:discover","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles:discover)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.discover"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.cancel"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:startBackfillJob","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.startBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:stopBackfillJob","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.stopBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}:fetchErrors","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchErrors)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.fetchErrors"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/manifests","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/manifests/{manifest}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/resources","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/resources/{resource}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{resource}/getIamPolicy","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.getIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/operations","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/operations/{operation}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}/types","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.listTypes"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}/types/{type}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.getType"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/types","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/types/{type}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/manifests","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/manifests/{manifest}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/resources","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/resources/{resource}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{resource}/getIamPolicy","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.getIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/operations","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/operations/{operation}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/types","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/manifests","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/manifests/{manifest}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/resources","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/resources/{resource}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{resource}/getIamPolicy","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.getIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/operations","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/operations/{operation}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}/types","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.listTypes"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}/types/{type}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.getType"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/types","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/cancelPreview","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelPreview)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.cancelPreview"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/stop","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.stop"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{resource}/setIamPolicy","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.setIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{resource}/testIamPermissions","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.testIamPermissions"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/cancelPreview","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelPreview)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.cancelPreview"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/stop","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.stop"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{resource}/setIamPolicy","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.setIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{resource}/testIamPermissions","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.testIamPermissions"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/cancelPreview","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelPreview)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.cancelPreview"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/stop","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.stop"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{resource}/setIamPolicy","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.setIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{resource}/testIamPermissions","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.testIamPermissions"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.update"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.3/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.4/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.5/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v4/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles","path_regex":"^(?:/dfareporting/v4/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertisers/{advertiserId}/invoices","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserInvoices.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/billingProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/billingProfiles/{billingProfileId}/billingAssignments","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingAssignments)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingAssignments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/billingProfiles/{billingProfileId}/billingRates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingRates)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingRates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/billingProfiles/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.billingProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/customEvents/batchinsert","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customEvents/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.customEvents.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/billingProfiles/{billingProfileId}/billingAssignments","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingAssignments)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingAssignments.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.5/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/billingProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets/{conversationDatasetsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/validationResult","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/answerRecords","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationDatasets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationDatasets.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationDatasets/{conversationDatasetsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationDatasets.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}/evaluations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.evaluations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.evaluations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/validationResult","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/answerRecords","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets/{conversationDatasetsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}/evaluations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.evaluations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.evaluations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/validationResult","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent:search","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/answerRecords","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/validationResult","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:search","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/answerRecords","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/operations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs/{changelogsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/continuousTestResults","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/continuousTestResults)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.continuousTestResults.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments/{deploymentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:lookupEnvironmentHistory","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupEnvironmentHistory)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.lookupEnvironmentHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/validationResult","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results/{resultsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:calculateCoverage","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:calculateCoverage)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.calculateCoverage"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/validationResult","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/operations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/operations","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs/{changelogsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/continuousTestResults","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/continuousTestResults)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.continuousTestResults.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments/{deploymentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:lookupEnvironmentHistory","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupEnvironmentHistory)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.lookupEnvironmentHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/validationResult","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results/{resultsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:calculateCoverage","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:calculateCoverage)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.calculateCoverage"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/validationResult","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/operations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/intents:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:restore","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:train","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationDatasets/{conversationDatasetsId}:importConversationData","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importConversationData)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationDatasets.importConversationData"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}:deploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.deploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}:undeploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.undeploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:restore","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:train","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets/{conversationDatasetsId}:importConversationData","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importConversationData)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.importConversationData"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}/evaluations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.evaluations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}:deploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.deploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}:undeploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.undeploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/intents:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:export","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:restore","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:train","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/messages:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.messages.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:compile","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:compile)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.compile"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:export","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:restore","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:train","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/messages:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.messages.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:start","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.start"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:stop","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.stop"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:deployFlow","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployFlow)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployFlow"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:runContinuousTest","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runContinuousTest)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.runContinuousTest"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:compareVersions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::compareVersions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.compareVersions"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:load","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::load)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.load"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:train","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:validate","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows:import","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}:run","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.run"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchDelete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchRun","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchRun)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchRun"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:import","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:restore","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:validate","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3alpha1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:start","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.start"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:stop","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.stop"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:deployFlow","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployFlow)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployFlow"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:runContinuousTest","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runContinuousTest)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.runContinuousTest"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:compareVersions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::compareVersions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.compareVersions"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:load","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::load)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.load"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:train","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:validate","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows:import","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}:run","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.run"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchDelete","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchRun","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchRun)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchRun"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:import","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:restore","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:validate","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"digitalassetlinks.googleapis.com","http_method":"GET","path_template":"/v1/assetlinks:check","path_regex":"^(?:/v1/assetlinks:check)$","service_name":"google.digitalassetlinks","resource_name":"digitalassetlinks.assetlinks.check"},{"hostname":"digitalassetlinks.googleapis.com","http_method":"GET","path_template":"/v1/statements:list","path_regex":"^(?:/v1/statements:list)$","service_name":"google.digitalassetlinks","resource_name":"digitalassetlinks.statements.list"},{"hostname":"digitalassetlinks.googleapis.com","http_method":"POST","path_template":"/v1/assetlinks:bulkCheck","path_regex":"^(?:/v1/assetlinks:bulkCheck)$","service_name":"google.digitalassetlinks","resource_name":"digitalassetlinks.assetlinks.bulkCheck"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.write"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations/{assignedLocationsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords/{negativeKeywordsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources/{assignedInventorySourcesId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/users/{usersId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations/{assignedLocationsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords/{negativeKeywordsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources/{assignedInventorySourcesId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/users/{usersId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers","path_regex":"^(?:/v1/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}:bulkListCampaignAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListCampaignAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.bulkListCampaignAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/channels","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/channels/{channelsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}:bulkListInsertionOrderAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListInsertionOrderAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.bulkListInsertionOrderAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/invoices","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/invoices:lookupInvoiceCurrency","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices:lookupInvoiceCurrency)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.lookupInvoiceCurrency"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}:bulkListLineItemAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListLineItemAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkListLineItemAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/locationLists/{locationListsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}:audit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::audit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.audit"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}:bulkListAdvertiserAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListAdvertiserAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.bulkListAdvertiserAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/combinedAudiences","path_regex":"^(?:/v1/combinedAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/combinedAudiences/{combinedAudiencesId}","path_regex":"^(?:/v1/combinedAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms","path_regex":"^(?:/v1/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts/{scriptsId}","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}:uploadScript","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::uploadScript)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.uploadScript"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customLists","path_regex":"^(?:/v1/customLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customLists/{customListsId}","path_regex":"^(?:/v1/customLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/firstAndThirdPartyAudiences","path_regex":"^(?:/v1/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v1/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/floodlightGroups/{floodlightGroupsId}","path_regex":"^(?:/v1/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/googleAudiences","path_regex":"^(?:/v1/googleAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/googleAudiences/{googleAudiencesId}","path_regex":"^(?:/v1/googleAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/guaranteedOrders","path_regex":"^(?:/v1/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v1/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySourceGroups","path_regex":"^(?:/v1/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySources","path_regex":"^(?:/v1/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v1/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners","path_regex":"^(?:/v1/partners)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/channels","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/channels/{channelsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/targetingTypes/{targetingTypesId}/targetingOptions","path_regex":"^(?:/v1/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/targetingTypes/{targetingTypesId}/targetingOptions/{targetingOptionsId}","path_regex":"^(?:/v1/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/users","path_regex":"^(?:/v1/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1beta/sdfdownloadtask/operations/{operationsId}","path_regex":"^(?:/v1beta/sdfdownloadtask/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtask.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1beta/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1beta/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1beta2/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1beta2/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1dev/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1dev/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers","path_regex":"^(?:/v2/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}:listAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/channels","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/channels/{channelsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}:listAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/invoices","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/invoices:lookupInvoiceCurrency","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices:lookupInvoiceCurrency)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.lookupInvoiceCurrency"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems:bulkListAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkListAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkListAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/locationLists/{locationListsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroupAds","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroupAds)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroupAds.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroupAds/{youtubeAdGroupAdsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroupAds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroupAds.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups/{youtubeAdGroupsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups/{youtubeAdGroupsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups/{youtubeAdGroupsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups:bulkListAdGroupAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups:bulkListAdGroupAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.bulkListAdGroupAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}:audit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::audit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.audit"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}:listAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/combinedAudiences","path_regex":"^(?:/v2/combinedAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/combinedAudiences/{combinedAudiencesId}","path_regex":"^(?:/v2/combinedAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms","path_regex":"^(?:/v2/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts/{scriptsId}","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}:uploadScript","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::uploadScript)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.uploadScript"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customLists","path_regex":"^(?:/v2/customLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customLists/{customListsId}","path_regex":"^(?:/v2/customLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/firstAndThirdPartyAudiences","path_regex":"^(?:/v2/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v2/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/floodlightGroups/{floodlightGroupsId}","path_regex":"^(?:/v2/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/googleAudiences","path_regex":"^(?:/v2/googleAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/googleAudiences/{googleAudiencesId}","path_regex":"^(?:/v2/googleAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/guaranteedOrders","path_regex":"^(?:/v2/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v2/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySourceGroups","path_regex":"^(?:/v2/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySources","path_regex":"^(?:/v2/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v2/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners","path_regex":"^(?:/v2/partners)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/channels","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/channels/{channelsId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v2/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/targetingTypes/{targetingTypesId}/targetingOptions","path_regex":"^(?:/v2/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/targetingTypes/{targetingTypesId}/targetingOptions/{targetingOptionsId}","path_regex":"^(?:/v2/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/users","path_regex":"^(?:/v2/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/users/{usersId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.get"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/channels/{channelId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/locationLists/{locationListId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v1/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/floodlightGroups/{floodlightGroupId}","path_regex":"^(?:/v1/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v1/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v1/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/partners/{partnersId}/channels/{channelId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/users/{usersId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/channels/{channelId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/locationLists/{locationListId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v2/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/floodlightGroups/{floodlightGroupId}","path_regex":"^(?:/v2/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v2/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v2/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/partners/{partnersId}/channels/{channelId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/users/{usersId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/media/{mediaId}","path_regex":"^(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/media/{mediaId}","path_regex":"^(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers","path_regex":"^(?:/v1/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListsId}/assignedLocations:bulkEdit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:bulkEdit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:replace","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/assets","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.assets.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/channels","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}:bulkEditLineItemAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditLineItemAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkEditLineItemAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems:generateDefault","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:generateDefault)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.generateDefault"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:activate","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.activate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:deactivate","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.deactivate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}:bulkEditAdvertiserAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditAdvertiserAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.bulkEditAdvertiserAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/customBiddingAlgorithms","path_regex":"^(?:/v1/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/firstAndThirdPartyAudiences","path_regex":"^(?:/v1/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}:editCustomerMatchMembers","path_regex":"^(?:/v1/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editCustomerMatchMembers)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.editCustomerMatchMembers"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/guaranteedOrders","path_regex":"^(?:/v1/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/guaranteedOrders/{guaranteedOrdersId}:editGuaranteedOrderReadAccessors","path_regex":"^(?:/v1/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editGuaranteedOrderReadAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.editGuaranteedOrderReadAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySourceGroups","path_regex":"^(?:/v1/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources:bulkEdit","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySources","path_regex":"^(?:/v1/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySources/{inventorySourcesId}:editInventorySourceReadWriteAccessors","path_regex":"^(?:/v1/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editInventorySourceReadWriteAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.editInventorySourceReadWriteAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/channels","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}:bulkEditPartnerAssignedTargetingOptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditPartnerAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.bulkEditPartnerAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/sdfdownloadtasks","path_regex":"^(?:/v1/sdfdownloadtasks)$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/targetingTypes/{targetingTypesId}/targetingOptions:search","path_regex":"^(?:/v1/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions:search)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.search"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/users","path_regex":"^(?:/v1/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}:bulkEditAssignedUserRoles","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditAssignedUserRoles)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.bulkEditAssignedUserRoles"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers","path_regex":"^(?:/v2/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListsId}/assignedLocations:bulkEdit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:bulkEdit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:replace","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/assets","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.assets.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/channels","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}:duplicate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::duplicate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.duplicate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems:bulkEditAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkEditAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkEditAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems:bulkUpdate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkUpdate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkUpdate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems:generateDefault","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:generateDefault)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.generateDefault"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:activate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.activate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:deactivate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.deactivate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}:editAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.editAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/customBiddingAlgorithms","path_regex":"^(?:/v2/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/firstAndThirdPartyAudiences","path_regex":"^(?:/v2/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}:editCustomerMatchMembers","path_regex":"^(?:/v2/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editCustomerMatchMembers)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.editCustomerMatchMembers"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/guaranteedOrders","path_regex":"^(?:/v2/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/guaranteedOrders/{guaranteedOrdersId}:editGuaranteedOrderReadAccessors","path_regex":"^(?:/v2/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editGuaranteedOrderReadAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.editGuaranteedOrderReadAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySourceGroups","path_regex":"^(?:/v2/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources:bulkEdit","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySources","path_regex":"^(?:/v2/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySources/{inventorySourcesId}:editInventorySourceReadWriteAccessors","path_regex":"^(?:/v2/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editInventorySourceReadWriteAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.editInventorySourceReadWriteAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnersId}/channels","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnersId}:editAssignedTargetingOptions","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.editAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/sdfdownloadtasks","path_regex":"^(?:/v2/sdfdownloadtasks)$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/targetingTypes/{targetingTypesId}/targetingOptions:search","path_regex":"^(?:/v2/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions:search)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.search"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/users","path_regex":"^(?:/v2/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/users/{usersId}:bulkEditAssignedUserRoles","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditAssignedUserRoles)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.bulkEditAssignedUserRoles"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/infoTypes","path_regex":"^(?:/v2/infoTypes)$","service_name":"google.dlp","resource_name":"dlp.infoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/locations/{locationsId}/infoTypes","path_regex":"^(?:/v2/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/infoTypes)$","service_name":"google.dlp","resource_name":"dlp.locations.infoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/dlpJobs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.dlpJobs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/content:deidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:deidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.content.deidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/content:inspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:inspect)$","service_name":"google.dlp","resource_name":"dlp.projects.content.inspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/content:reidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:reidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.content.reidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/dlpJobs/{dlpJobsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.cancel"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/image:redact","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/image:redact)$","service_name":"google.dlp","resource_name":"dlp.projects.image.redact"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}:activate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.activate"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/content:deidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:deidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.content.deidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/content:inspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:inspect)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.content.inspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/content:reidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:reidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.content.reidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.cancel"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}:finish","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::finish)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.finish"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}:hybridInspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::hybridInspect)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.hybridInspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/image:redact","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/image:redact)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.image.redact"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}:activate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.activate"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}:hybridInspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::hybridInspect)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.hybridInspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.create"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/policies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/policies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/policies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/policies","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{projectsId}/managedZones/{managedZonesId}:getIamPolicy","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.getIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{projectsId}/managedZones/{managedZonesId}:setIamPolicy","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.setIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{projectsId}/managedZones/{managedZonesId}:testIamPermissions","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dns","resource_name":"dns.managedZones.testIamPermissions"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/managedZones","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/policies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{projectsId}/managedZones/{managedZonesId}:getIamPolicy","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.getIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{projectsId}/managedZones/{managedZonesId}:setIamPolicy","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.setIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{projectsId}/managedZones/{managedZonesId}:testIamPermissions","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dns","resource_name":"dns.managedZones.testIamPermissions"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/managedZones","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/policies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/policies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2beta1/projects/{project}/managedZones","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2beta1/projects/{project}/policies","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"docs.googleapis.com","http_method":"GET","path_template":"/v1/documents/{documentId}","path_regex":"^(?:/v1/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.docs","resource_name":"docs.documents.get"},{"hostname":"docs.googleapis.com","http_method":"POST","path_template":"/v1/documents","path_regex":"^(?:/v1/documents)$","service_name":"google.docs","resource_name":"docs.documents.create"},{"hostname":"docs.googleapis.com","http_method":"POST","path_template":"/v1/documents/{documentId}:batchUpdate","path_regex":"^(?:/v1/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.docs","resource_name":"docs.documents.batchUpdate"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.operations.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.delete"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processorTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processorTypes/{processorTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:fetchProcessorTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchProcessorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.fetchProcessorTypes"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processorTypes","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processorTypes/{processorTypesId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}:fetchProcessorTypes","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchProcessorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.fetchProcessorTypes"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.cancel"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.create"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/humanReviewConfig:reviewDocument","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/humanReviewConfig:reviewDocument)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.humanReviewConfig.reviewDocument"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:batchProcess","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:deploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.deploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:evaluateProcessorVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluateProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:process","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:undeploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.undeploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions:train","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions:train)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.train"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:batchProcess","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.disable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.enable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:process","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:setDefaultProcessorVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.setDefaultProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/documents:batchProcess","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.documents.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/documents:process","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:process)$","service_name":"google.documentai","resource_name":"documentai.projects.documents.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/documents:batchProcess","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.documents.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/documents:process","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.documents.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.cancel"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.create"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/humanReviewConfig:reviewDocument","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/humanReviewConfig:reviewDocument)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.humanReviewConfig.reviewDocument"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:batchProcess","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:deploy","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.deploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:evaluateProcessorVersion","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluateProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:process","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:undeploy","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.undeploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions:importProcessorVersion","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions:importProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.importProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions:train","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions:train)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.train"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:batchProcess","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:disable","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.disable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:enable","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.enable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:process","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:setDefaultProcessorVersion","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.setDefaultProcessorVersion"},{"hostname":"domains.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.delete"},{"hostname":"domains.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.delete"},{"hostname":"domains.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.delete"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.domains","resource_name":"domains.projects.locations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.getIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveAuthorizationCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveImportableDomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveImportableDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveImportableDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveRegisterParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveRegisterParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveRegisterParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveTransferParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveTransferParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveTransferParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:searchDomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:searchDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.searchDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.domains","resource_name":"domains.projects.locations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.getIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveAuthorizationCode","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:retrieveImportableDomains","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveImportableDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveImportableDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:retrieveRegisterParameters","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveRegisterParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveRegisterParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:retrieveTransferParameters","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveTransferParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveTransferParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:searchDomains","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:searchDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.searchDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.domains","resource_name":"domains.projects.locations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.getIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveAuthorizationCode","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveImportableDomains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveImportableDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveImportableDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveRegisterParameters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveRegisterParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveRegisterParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveTransferParameters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveTransferParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveTransferParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:searchDomains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:searchDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.searchDomains"},{"hostname":"domains.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.patch"},{"hostname":"domains.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.patch"},{"hostname":"domains.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.patch"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureContactSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureContactSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureContactSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureDnsSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureDnsSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureDnsSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureManagementSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureManagementSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureManagementSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.export"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:resetAuthorizationCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.resetAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.setIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.testIamPermissions"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:import)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.import"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:register","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:register)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.register"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:transfer","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:transfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.transfer"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureContactSettings","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureContactSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureContactSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureDnsSettings","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureDnsSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureDnsSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureManagementSettings","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureManagementSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureManagementSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:export","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.export"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:resetAuthorizationCode","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.resetAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.setIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.testIamPermissions"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:import","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:import)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.import"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:register","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:register)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.register"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:transfer","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:transfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.transfer"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureContactSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureContactSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureContactSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureDnsSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureDnsSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureDnsSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureManagementSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureManagementSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureManagementSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.export"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:resetAuthorizationCode","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.resetAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.setIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.testIamPermissions"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:import)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.import"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:register","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:register)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.register"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:transfer","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:transfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.transfer"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/autnum/{autnumId}","path_regex":"^(?:/v1/autnum/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.autnum.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/domain/{domainId}","path_regex":"^(?:/v1/domain/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.domain.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/domains","path_regex":"^(?:/v1/domains)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getDomains"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/entities","path_regex":"^(?:/v1/entities)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getEntities"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/entity/{entityId}","path_regex":"^(?:/v1/entity/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.entity.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/help","path_regex":"^(?:/v1/help)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getHelp"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/ip","path_regex":"^(?:/v1/ip)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getIp"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/ip/{ipId}/{ipId1}","path_regex":"^(?:/v1/ip/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.ip.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/nameserver/{nameserverId}","path_regex":"^(?:/v1/nameserver/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.nameserver.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/nameservers","path_regex":"^(?:/v1/nameservers)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getNameservers"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"DELETE","path_template":"/doubleclickbidmanager/v1.1/query/{queryId}","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.deletequery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"DELETE","path_template":"/v2/queries/{queryId}","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.delete"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/doubleclickbidmanager/v1.1/queries","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/queries)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.listqueries"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/doubleclickbidmanager/v1.1/queries/{queryId}/reports","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.reports.listreports"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/doubleclickbidmanager/v1.1/query/{queryId}","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.getquery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries","path_regex":"^(?:/v2/queries)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.list"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries/{queryId}","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.get"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries/{queryId}/reports","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.reports.list"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries/{queryId}/reports/{reportId}","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.reports.get"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/doubleclickbidmanager/v1.1/query","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.createquery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/doubleclickbidmanager/v1.1/query/{queryId}","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.runquery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/v2/queries","path_regex":"^(?:/v2/queries)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.create"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/v2/queries/{queryId}:run","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.run"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/agency/{agencyId}/advertiser/{advertiserId}/engine/{engineAccountId}/conversion","path_regex":"^(?:/doubleclicksearch/v2/agency/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engine/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.get"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/agency/{agencyId}/advertiser/{advertiserId}/idmapping","path_regex":"^(?:/doubleclicksearch/v2/agency/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idmapping)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.getIdMappingFile"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/agency/{agencyId}/advertiser/{advertiserId}/savedcolumns","path_regex":"^(?:/doubleclicksearch/v2/agency/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedcolumns)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.savedColumns.list"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/customer/{customerId}/conversion","path_regex":"^(?:/doubleclicksearch/v2/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.getByCustomerId"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/reports/{reportId}","path_regex":"^(?:/doubleclicksearch/v2/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.get"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/reports/{reportId}/files/{reportFragment}","path_regex":"^(?:/doubleclicksearch/v2/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.getFile"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/conversion","path_regex":"^(?:/doubleclicksearch/v2/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.insert"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/conversion/updateAvailability","path_regex":"^(?:/doubleclicksearch/v2/conversion/updateAvailability)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.updateAvailability"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/reports","path_regex":"^(?:/doubleclicksearch/v2/reports)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.request"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/reports/generate","path_regex":"^(?:/doubleclicksearch/v2/reports/generate)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.generate"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"PUT","path_template":"/doubleclicksearch/v2/conversion","path_regex":"^(?:/doubleclicksearch/v2/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.update"},{"hostname":"driveactivity.googleapis.com","http_method":"POST","path_template":"/v2/activity:query","path_regex":"^(?:/v2/activity:query)$","service_name":"google.driveactivity","resource_name":"driveactivity.activity.query"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2/labels/{labelsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2/labels/{labelsId}/permissions/{permissionsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions/{permissionsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2beta/labels/{labelsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2beta/labels/{labelsId}/permissions/{permissionsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions/{permissionsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels","path_regex":"^(?:/v2/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.get"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/locks","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/locks","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/limits/label","path_regex":"^(?:/v2/limits/label)$","service_name":"google.drivelabels","resource_name":"drivelabels.limits.getLabel"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/users/{usersId}/capabilities","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capabilities)$","service_name":"google.drivelabels","resource_name":"drivelabels.users.getCapabilities"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels","path_regex":"^(?:/v2beta/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.get"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/locks","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/locks","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/limits/label","path_regex":"^(?:/v2beta/limits/label)$","service_name":"google.drivelabels","resource_name":"drivelabels.limits.getLabel"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/users/{usersId}/capabilities","path_regex":"^(?:/v2beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capabilities)$","service_name":"google.drivelabels","resource_name":"drivelabels.users.getCapabilities"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2/labels/{labelsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2beta/labels/{labelsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels","path_regex":"^(?:/v2/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/permissions:batchDelete","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/permissions:batchUpdate","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions:batchDelete","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions:batchUpdate","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:delta","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delta)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delta"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:disable","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.disable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:enable","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.enable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:publish","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.publish"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:updateLabelCopyMode","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateLabelCopyMode)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updateLabelCopyMode"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels","path_regex":"^(?:/v2beta/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/permissions:batchDelete","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/permissions:batchUpdate","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions:batchDelete","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions:batchUpdate","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:delta","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delta)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delta"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:disable","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.disable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:enable","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.enable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:publish","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.publish"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:updateLabelCopyMode","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateLabelCopyMode)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updateLabelCopyMode"},{"hostname":"essentialcontacts.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/contacts/{contactsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.delete"},{"hostname":"essentialcontacts.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/contacts/{contactsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.delete"},{"hostname":"essentialcontacts.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/contacts/{contactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.delete"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/contacts","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.list"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/contacts/{contactsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.get"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/contacts:compute","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:compute)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.compute"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/contacts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.list"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/contacts/{contactsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.get"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/contacts:compute","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:compute)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.compute"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/contacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.list"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/contacts/{contactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.get"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/contacts:compute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:compute)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.compute"},{"hostname":"essentialcontacts.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/contacts/{contactsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.patch"},{"hostname":"essentialcontacts.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/contacts/{contactsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.patch"},{"hostname":"essentialcontacts.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/contacts/{contactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.patch"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/contacts","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.create"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/contacts:sendTestMessage","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:sendTestMessage)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.sendTestMessage"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/contacts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.create"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/contacts:sendTestMessage","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:sendTestMessage)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.sendTestMessage"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/contacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.create"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/contacts:sendTestMessage","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:sendTestMessage)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.sendTestMessage"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.delete"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/googleChannelConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleChannelConfig)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.getGoogleChannelConfig"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.providers.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.providers.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.patch"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/googleChannelConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleChannelConfig)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.updateGoogleChannelConfig"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.patch"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.patch"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.testIamPermissions"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.testIamPermissions"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.cancel"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.testIamPermissions"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.cancel"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.testIamPermissions"},{"hostname":"factchecktools.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/pages/{pagesId}","path_regex":"^(?:/v1alpha1/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.delete"},{"hostname":"factchecktools.googleapis.com","http_method":"GET","path_template":"/v1alpha1/claims:search","path_regex":"^(?:/v1alpha1/claims:search)$","service_name":"google.factchecktools","resource_name":"factchecktools.claims.search"},{"hostname":"factchecktools.googleapis.com","http_method":"GET","path_template":"/v1alpha1/pages","path_regex":"^(?:/v1alpha1/pages)$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.list"},{"hostname":"factchecktools.googleapis.com","http_method":"GET","path_template":"/v1alpha1/pages/{pagesId}","path_regex":"^(?:/v1alpha1/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.get"},{"hostname":"factchecktools.googleapis.com","http_method":"POST","path_template":"/v1alpha1/pages","path_regex":"^(?:/v1alpha1/pages)$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.create"},{"hostname":"factchecktools.googleapis.com","http_method":"PUT","path_template":"/v1alpha1/pages/{pagesId}","path_regex":"^(?:/v1alpha1/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.update"},{"hostname":"fcm.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/messages:send","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:send)$","service_name":"google.fcm","resource_name":"fcm.projects.messages.send"},{"hostname":"fcmdata.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/deliveryData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryData)$","service_name":"google.fcmdata","resource_name":"fcmdata.projects.androidApps.deliveryData.list"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares/{sharesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.delete"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.file","resource_name":"file.projects.locations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.file","resource_name":"file.projects.locations.operations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.file","resource_name":"file.projects.locations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares)$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares/{sharesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.file","resource_name":"file.projects.locations.operations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.get"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares/{sharesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.patch"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.file","resource_name":"file.projects.locations.instances.restore"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:revert","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.file","resource_name":"file.projects.locations.instances.revert"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.file","resource_name":"file.projects.locations.operations.cancel"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares)$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restore","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.file","resource_name":"file.projects.locations.instances.restore"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:revert","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.file","resource_name":"file.projects.locations.instances.revert"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.file","resource_name":"file.projects.locations.operations.cancel"},{"hostname":"firebase.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/sha/{shaId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sha/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.sha.delete"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/availableProjects","path_regex":"^(?:/v1beta1/availableProjects)$","service_name":"google.firebase","resource_name":"firebase.availableProjects.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.operations.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects","path_regex":"^(?:/v1beta1/projects)$","service_name":"google.firebase","resource_name":"firebase.projects.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/adminSdkConfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminSdkConfig)$","service_name":"google.firebase","resource_name":"firebase.projects.getAdminSdkConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/analyticsDetails","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyticsDetails)$","service_name":"google.firebase","resource_name":"firebase.projects.getAnalyticsDetails"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.getConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/sha","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sha)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.sha.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/availableLocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/availableLocations)$","service_name":"google.firebase","resource_name":"firebase.projects.availableLocations.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/iosApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.getConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/webApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.getConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}:searchApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchApps)$","service_name":"google.firebase","resource_name":"firebase.projects.searchApps"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.patch"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.patch"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.patch"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.patch"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/sha","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sha)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.sha.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}:remove","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::remove)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.remove"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.undelete"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/defaultLocation:finalize","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultLocation:finalize)$","service_name":"google.firebase","resource_name":"firebase.projects.defaultLocation.finalize"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/iosApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}:remove","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::remove)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.remove"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.undelete"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/webApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}:remove","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::remove)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.remove"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.undelete"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:addFirebase","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFirebase)$","service_name":"google.firebase","resource_name":"firebase.projects.addFirebase"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:addGoogleAnalytics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addGoogleAnalytics)$","service_name":"google.firebase","resource_name":"firebase.projects.addGoogleAnalytics"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:removeAnalytics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeAnalytics)$","service_name":"google.firebase","resource_name":"firebase.projects.removeAnalytics"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.delete"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.delete"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/jwks","path_regex":"^(?:/v1/jwks)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.jwks.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/appAttestConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/appAttestConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/deviceCheckConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/deviceCheckConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/playIntegrityConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/playIntegrityConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/recaptchaEnterpriseConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaEnterpriseConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/recaptchaV3Config:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaV3Config:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/safetyNetConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/safetyNetConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/jwks","path_regex":"^(?:/v1beta/jwks)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.jwks.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/appAttestConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/appAttestConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/deviceCheckConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/deviceCheckConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/playIntegrityConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/playIntegrityConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/recaptchaConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/recaptchaEnterpriseConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaEnterpriseConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/recaptchaV3Config:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaV3Config:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/safetyNetConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/safetyNetConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/services","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.create"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAssertion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAssertion)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAssertion"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAttestation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAttestation)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAttestation"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeCustomToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeCustomToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeCustomToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeDebugToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDebugToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDebugToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeDeviceCheckToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDeviceCheckToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDeviceCheckToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangePlayIntegrityToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangePlayIntegrityToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangePlayIntegrityToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaEnterpriseToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaEnterpriseToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaEnterpriseToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaV3Token","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaV3Token)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaV3Token"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeSafetyNetToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeSafetyNetToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeSafetyNetToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:generateAppAttestChallenge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAppAttestChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generateAppAttestChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:generatePlayIntegrityChallenge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generatePlayIntegrityChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generatePlayIntegrityChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services:batchUpdate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchUpdate)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.batchUpdate"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.create"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAssertion","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAssertion)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAssertion"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAttestation","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAttestation)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAttestation"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeCustomToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeCustomToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeCustomToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeDebugToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDebugToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDebugToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeDeviceCheckToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDeviceCheckToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDeviceCheckToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangePlayIntegrityToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangePlayIntegrityToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangePlayIntegrityToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaEnterpriseToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaEnterpriseToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaEnterpriseToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaV3Token","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaV3Token)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaV3Token"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeSafetyNetToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeSafetyNetToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeSafetyNetToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:generateAppAttestChallenge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAppAttestChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generateAppAttestChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:generatePlayIntegrityChallenge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generatePlayIntegrityChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generatePlayIntegrityChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/services:batchUpdate","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchUpdate)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.batchUpdate"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}:verifyAppCheckToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verifyAppCheckToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.verifyAppCheckToken"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/feedbackReports/{feedbackReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.feedbackReports.delete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.delete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.delete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/aabInfo","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aabInfo)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.getAabInfo"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/feedbackReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackReports)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.feedbackReports.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/feedbackReports/{feedbackReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.feedbackReports.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/testers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.patch"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.patch"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/testers/{testersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.patch"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.cancel"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.wait"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}:distribute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::distribute)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.distribute"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases:batchDelete)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.batchDelete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases:upload)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.media.upload"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.create"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/groups/{groupsId}:batchJoin","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchJoin)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.batchJoin"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/groups/{groupsId}:batchLeave","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchLeave)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.batchLeave"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/testers:batchAdd","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers:batchAdd)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.batchAdd"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/testers:batchRemove","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers:batchRemove)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.batchRemove"},{"hostname":"firebasedatabase.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.delete"},{"hostname":"firebasedatabase.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.list"},{"hostname":"firebasedatabase.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.get"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.create"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:disable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.disable"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reenable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reenable)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.reenable"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:undelete","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.undelete"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"GET","path_template":"/v1/{dynamicLink}/linkStats","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/linkStats)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.getLinkStats"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/installAttribution","path_regex":"^(?:/v1/installAttribution)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.installAttribution"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/managedShortLinks:create","path_regex":"^(?:/v1/managedShortLinks:create)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.managedShortLinks.create"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/reopenAttribution","path_regex":"^(?:/v1/reopenAttribution)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.reopenAttribution"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/shortLinks","path_regex":"^(?:/v1/shortLinks)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.shortLinks.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.operations.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.operations.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.operations.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.getConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}/files","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.files.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.getConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}/files","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.files.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.updateConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.updateConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.operations.cancel"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}:populateFiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::populateFiles)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.populateFiles"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions:clone","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:clone)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.clone"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}:populateFiles","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::populateFiles)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.populateFiles"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/versions:clone","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:clone)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.clone"},{"hostname":"firebasehosting.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.update"},{"hostname":"firebasehosting.googleapis.com","http_method":"PUT","path_template":"/v1beta1/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.update"},{"hostname":"firebaseml.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.operations.delete"},{"hostname":"firebaseml.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.delete"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.firebaseml","resource_name":"firebaseml.operations.list"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/models","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.list"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.get"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}:download","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.download"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.operations.get"},{"hostname":"firebaseml.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.patch"},{"hostname":"firebaseml.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firebaseml","resource_name":"firebaseml.operations.cancel"},{"hostname":"firebaseml.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/models","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.create"},{"hostname":"firebaseremoteconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/remoteConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remoteConfig)$","service_name":"google.firebaseremoteconfig","resource_name":"firebaseremoteconfig.projects.getRemoteConfig"},{"hostname":"firebaseremoteconfig.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/remoteConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remoteConfig)$","service_name":"google.firebaseremoteconfig","resource_name":"firebaseremoteconfig.projects.updateRemoteConfig"},{"hostname":"firebaserules.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.delete"},{"hostname":"firebaserules.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/rulesets/{rulesetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.delete"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.list"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.get"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/releases/{releasesId}:getExecutable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getExecutable)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.getExecutable"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/rulesets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.list"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/rulesets/{rulesetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.get"},{"hostname":"firebaserules.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.patch"},{"hostname":"firebaserules.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.create"},{"hostname":"firebaserules.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/rulesets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.create"},{"hostname":"firebaserules.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:test","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::test)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.test"},{"hostname":"firebasestorage.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/buckets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.list"},{"hostname":"firebasestorage.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/buckets/{bucketsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.get"},{"hostname":"firebasestorage.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/buckets/{bucketsId}:addFirebase","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFirebase)$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.addFirebase"},{"hostname":"firebasestorage.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/buckets/{bucketsId}:removeFirebase","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFirebase)$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.removeFirebase"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes/{indexesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.delete"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{collectionId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listDocuments"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}/{collectionId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.firestore","resource_name":"firestore.projects.locations.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.locations.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{collectionId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listDocuments"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}/{collectionId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes/{indexesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.get"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.patch"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{collectionId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.createDocument"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:listCollectionIds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listCollectionIds)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listCollectionIds"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:partitionQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.partitionQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runAggregationQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runAggregationQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchGet)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchGet"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:batchWrite","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchWrite)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchWrite"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:beginTransaction","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:beginTransaction)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.beginTransaction"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:commit)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.commit"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:listen","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:listen)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listen"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:rollback)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.rollback"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:write","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:write)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.write"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.cancel"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}:exportDocuments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.exportDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}:importDocuments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.importDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{collectionId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.createDocument"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:listCollectionIds","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listCollectionIds)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listCollectionIds"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:partitionQuery","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.partitionQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runAggregationQuery","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runAggregationQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runQuery","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:batchGet","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchGet)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchGet"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:batchWrite","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchWrite)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchWrite"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:beginTransaction","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:beginTransaction)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.beginTransaction"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:commit","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:commit)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.commit"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:listen","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:listen)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listen"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:rollback)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.rollback"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:write","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:write)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.write"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}:exportDocuments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.exportDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}:importDocuments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.importDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}:exportDocuments","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.exportDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}:importDocuments","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.importDocuments"},{"hostname":"fitness.googleapis.com","http_method":"DELETE","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.delete"},{"hostname":"fitness.googleapis.com","http_method":"DELETE","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/datasets/{datasetId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.datasets.delete"},{"hostname":"fitness.googleapis.com","http_method":"DELETE","path_template":"/fitness/v1/users/{userId}/sessions/{sessionId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.sessions.delete"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.list"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.get"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/dataPointChanges","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPointChanges)$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.dataPointChanges.list"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/datasets/{datasetId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.datasets.get"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/sessions","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.fitness","resource_name":"fitness.users.sessions.list"},{"hostname":"fitness.googleapis.com","http_method":"PATCH","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/datasets/{datasetId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.datasets.patch"},{"hostname":"fitness.googleapis.com","http_method":"POST","path_template":"/fitness/v1/users/{userId}/dataSources","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.create"},{"hostname":"fitness.googleapis.com","http_method":"POST","path_template":"/fitness/v1/users/{userId}/dataset:aggregate","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset:aggregate)$","service_name":"google.fitness","resource_name":"fitness.users.dataset.aggregate"},{"hostname":"fitness.googleapis.com","http_method":"PUT","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.update"},{"hostname":"fitness.googleapis.com","http_method":"PUT","path_template":"/fitness/v1/users/{userId}/sessions/{sessionId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.sessions.update"},{"hostname":"forms.googleapis.com","http_method":"DELETE","path_template":"/v1/forms/{formId}/watches/{watchId}","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.forms","resource_name":"forms.forms.watches.delete"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.forms","resource_name":"forms.forms.get"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}/responses","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responses)$","service_name":"google.forms","resource_name":"forms.forms.responses.list"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}/responses/{responseId}","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.forms","resource_name":"forms.forms.responses.get"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}/watches","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches)$","service_name":"google.forms","resource_name":"forms.forms.watches.list"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms","path_regex":"^(?:/v1/forms)$","service_name":"google.forms","resource_name":"forms.forms.create"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms/{formId}/watches","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches)$","service_name":"google.forms","resource_name":"forms.forms.watches.create"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms/{formId}/watches/{watchId}:renew","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::renew)$","service_name":"google.forms","resource_name":"forms.forms.watches.renew"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms/{formId}:batchUpdate","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.forms","resource_name":"forms.forms.batchUpdate"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/achievements","path_regex":"^(?:/games/v1/achievements)$","service_name":"google.games","resource_name":"games.achievementDefinitions.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/applications/{applicationId}","path_regex":"^(?:/games/v1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.applications.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/applications/{applicationId}/verify","path_regex":"^(?:/games/v1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verify)$","service_name":"google.games","resource_name":"games.applications.verify"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/eventDefinitions","path_regex":"^(?:/games/v1/eventDefinitions)$","service_name":"google.games","resource_name":"games.events.listDefinitions"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/events","path_regex":"^(?:/games/v1/events)$","service_name":"google.games","resource_name":"games.events.listByPlayer"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards","path_regex":"^(?:/games/v1/leaderboards)$","service_name":"google.games","resource_name":"games.leaderboards.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.leaderboards.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards/{leaderboardId}/scores/{collection}","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.scores.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards/{leaderboardId}/window/{collection}","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/window/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.scores.listWindow"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/metagameConfig","path_regex":"^(?:/games/v1/metagameConfig)$","service_name":"google.games","resource_name":"games.metagame.getMetagameConfig"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/me/multipleApplicationPlayerIds","path_regex":"^(?:/games/v1/players/me/multipleApplicationPlayerIds)$","service_name":"google.games","resource_name":"games.players.getMultipleApplicationPlayerIds"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/me/players/{collection}","path_regex":"^(?:/games/v1/players/me/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.players.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/me/scopedIds","path_regex":"^(?:/games/v1/players/me/scopedIds)$","service_name":"google.games","resource_name":"games.players.getScopedPlayerIds"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.players.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/achievements","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/achievements)$","service_name":"google.games","resource_name":"games.achievements.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/categories/{collection}","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/categories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.metagame.listCategoriesByPlayer"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/leaderboards/{leaderboardId}/scores/{timeSpan}","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.scores.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/snapshots","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.games","resource_name":"games.snapshots.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/revisions/check","path_regex":"^(?:/games/v1/revisions/check)$","service_name":"google.games","resource_name":"games.revisions.check"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/snapshots/{snapshotId}","path_regex":"^(?:/games/v1/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.snapshots.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/stats","path_regex":"^(?:/games/v1/stats)$","service_name":"google.games","resource_name":"games.stats.get"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/updateMultiple","path_regex":"^(?:/games/v1/achievements/updateMultiple)$","service_name":"google.games","resource_name":"games.achievements.updateMultiple"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/increment","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/increment)$","service_name":"google.games","resource_name":"games.achievements.increment"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/reveal","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reveal)$","service_name":"google.games","resource_name":"games.achievements.reveal"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/setStepsAtLeast","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setStepsAtLeast)$","service_name":"google.games","resource_name":"games.achievements.setStepsAtLeast"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/unlock","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unlock)$","service_name":"google.games","resource_name":"games.achievements.unlock"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/applications/getEndPoint","path_regex":"^(?:/games/v1/applications/getEndPoint)$","service_name":"google.games","resource_name":"games.applications.getEndPoint"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/applications/played","path_regex":"^(?:/games/v1/applications/played)$","service_name":"google.games","resource_name":"games.applications.played"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/events","path_regex":"^(?:/games/v1/events)$","service_name":"google.games","resource_name":"games.events.record"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/leaderboards/scores","path_regex":"^(?:/games/v1/leaderboards/scores)$","service_name":"google.games","resource_name":"games.scores.submitMultiple"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/leaderboards/{leaderboardId}/scores","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores)$","service_name":"google.games","resource_name":"games.scores.submit"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"DELETE","path_template":"/games/v1configuration/achievements/{achievementId}","path_regex":"^(?:/games/v1configuration/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.delete"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"DELETE","path_template":"/games/v1configuration/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1configuration/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.delete"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/achievements/{achievementId}","path_regex":"^(?:/games/v1configuration/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.get"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/applications/{applicationId}/achievements","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/achievements)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.list"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/applications/{applicationId}/leaderboards","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leaderboards)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.list"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1configuration/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.get"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"POST","path_template":"/games/v1configuration/applications/{applicationId}/achievements","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/achievements)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.insert"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"POST","path_template":"/games/v1configuration/applications/{applicationId}/leaderboards","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leaderboards)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.insert"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"PUT","path_template":"/games/v1configuration/achievements/{achievementId}","path_regex":"^(?:/games/v1configuration/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.update"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"PUT","path_template":"/games/v1configuration/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1configuration/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.update"},{"hostname":"gameservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.delete"},{"hostname":"gameservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.delete"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.get"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.getIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.get"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.get"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.getIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.get"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.setIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.testIamPermissions"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.cancel"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.setIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.testIamPermissions"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.cancel"},{"hostname":"gamesmanagement.googleapis.com","http_method":"DELETE","path_template":"/games/v1management/applications/{applicationId}/players/hidden/{playerId}","path_regex":"^(?:/games/v1management/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/players/hidden/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesManagement","resource_name":"gamesManagement.players.unhide"},{"hostname":"gamesmanagement.googleapis.com","http_method":"GET","path_template":"/games/v1management/applications/{applicationId}/players/hidden","path_regex":"^(?:/games/v1management/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/players/hidden)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.applications.listHidden"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/reset","path_regex":"^(?:/games/v1management/achievements/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetAll"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/resetAllForAllPlayers","path_regex":"^(?:/games/v1management/achievements/resetAllForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetAllForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/resetMultipleForAllPlayers","path_regex":"^(?:/games/v1management/achievements/resetMultipleForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetMultipleForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/{achievementId}/reset","path_regex":"^(?:/games/v1management/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.reset"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/{achievementId}/resetForAllPlayers","path_regex":"^(?:/games/v1management/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/applications/{applicationId}/players/hidden/{playerId}","path_regex":"^(?:/games/v1management/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/players/hidden/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesManagement","resource_name":"gamesManagement.players.hide"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/reset","path_regex":"^(?:/games/v1management/events/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetAll"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/resetAllForAllPlayers","path_regex":"^(?:/games/v1management/events/resetAllForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetAllForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/resetMultipleForAllPlayers","path_regex":"^(?:/games/v1management/events/resetMultipleForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetMultipleForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/{eventId}/reset","path_regex":"^(?:/games/v1management/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.reset"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/{eventId}/resetForAllPlayers","path_regex":"^(?:/games/v1management/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/leaderboards/{leaderboardId}/scores/reset","path_regex":"^(?:/games/v1management/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.reset"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/leaderboards/{leaderboardId}/scores/resetForAllPlayers","path_regex":"^(?:/games/v1management/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/resetForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/scores/reset","path_regex":"^(?:/games/v1management/scores/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetAll"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/scores/resetAllForAllPlayers","path_regex":"^(?:/games/v1management/scores/resetAllForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetAllForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/scores/resetMultipleForAllPlayers","path_regex":"^(?:/games/v1management/scores/resetMultipleForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetMultipleForAllPlayers"},{"hostname":"genomics.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/pipelines/{pipelineId}","path_regex":"^(?:/v1alpha2/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.pipelines.delete"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/operations","path_regex":"^(?:/v1alpha2/operations)$","service_name":"google.genomics","resource_name":"genomics.operations.list"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/operations/{operationsId}","path_regex":"^(?:/v1alpha2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.operations.get"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/pipelines","path_regex":"^(?:/v1alpha2/pipelines)$","service_name":"google.genomics","resource_name":"genomics.pipelines.list"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/pipelines/{pipelineId}","path_regex":"^(?:/v1alpha2/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.pipelines.get"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/pipelines:getControllerConfig","path_regex":"^(?:/v1alpha2/pipelines:getControllerConfig)$","service_name":"google.genomics","resource_name":"genomics.pipelines.getControllerConfig"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/operations","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.genomics","resource_name":"genomics.projects.operations.list"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.projects.operations.get"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v1alpha2/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.genomics","resource_name":"genomics.operations.cancel"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v1alpha2/pipelines","path_regex":"^(?:/v1alpha2/pipelines)$","service_name":"google.genomics","resource_name":"genomics.pipelines.create"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v1alpha2/pipelines:run","path_regex":"^(?:/v1alpha2/pipelines:run)$","service_name":"google.genomics","resource_name":"genomics.pipelines.run"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/pipelines:run","path_regex":"^(?:/v2alpha1/pipelines:run)$","service_name":"google.genomics","resource_name":"genomics.pipelines.run"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.genomics","resource_name":"genomics.projects.operations.cancel"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/workers/{workersId}:checkIn","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkIn)$","service_name":"google.genomics","resource_name":"genomics.projects.workers.checkIn"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/workers/{id}:checkIn","path_regex":"^(?:/v2alpha1/workers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkIn)$","service_name":"google.genomics","resource_name":"genomics.workers.checkIn"},{"hostname":"genomics.googleapis.com","http_method":"PUT","path_template":"/v1alpha2/pipelines:setOperationStatus","path_regex":"^(?:/v1alpha2/pipelines:setOperationStatus)$","service_name":"google.genomics","resource_name":"genomics.pipelines.setOperationStatus"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.deleteOperations"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.operations.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.operations.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.operations.cancel"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.organizations.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships:listAdmin","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:listAdmin)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.listAdmin"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.organizations.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateExclusivityManifest","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateExclusivityManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateExclusivityManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships:validateExclusivity","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:validateExclusivity)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.validateExclusivity"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships:validateCreate","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:validateCreate)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.validateCreate"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/global/memberships:initializeHub","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/memberships:initializeHub)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.global.memberships.initializeHub"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/rbacrolebindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.namespaces.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/drafts/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.drafts.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/messages/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.messages.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/cse/identities/{cseEmailAddress}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/delegates/{delegateEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/filters/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses/{forwardingEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/threads/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.threads.delete"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/drafts","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts)$","service_name":"google.gmail","resource_name":"gmail.users.drafts.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/drafts/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.drafts.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/history","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.gmail","resource_name":"gmail.users.history.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/labels","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.gmail","resource_name":"gmail.users.labels.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/messages","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.gmail","resource_name":"gmail.users.messages.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/messages/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.messages.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/messages/{messageId}/attachments/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.messages.attachments.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/profile","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profile)$","service_name":"google.gmail","resource_name":"gmail.users.getProfile"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/autoForwarding","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/autoForwarding)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getAutoForwarding"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/identities","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/identities/{cseEmailAddress}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/delegates","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates)$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/delegates/{delegateEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/filters","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters)$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/filters/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses)$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses/{forwardingEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/imap","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/imap)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getImap"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/language","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/language)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getLanguage"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/pop","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/pop)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getPop"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/vacation","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/vacation)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getVacation"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/threads","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads)$","service_name":"google.gmail","resource_name":"gmail.users.threads.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/threads/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.threads.get"},{"hostname":"gmail.googleapis.com","http_method":"PATCH","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.patch"},{"hostname":"gmail.googleapis.com","http_method":"PATCH","path_template":"/gmail/v1/users/{userId}/settings/cse/identities/{emailAddress}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.patch"},{"hostname":"gmail.googleapis.com","http_method":"PATCH","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.patch"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/drafts","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts)$","service_name":"google.gmail","resource_name":"gmail.users.drafts.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/drafts/send","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/send)$","service_name":"google.gmail","resource_name":"gmail.users.drafts.send"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/labels","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.gmail","resource_name":"gmail.users.labels.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.gmail","resource_name":"gmail.users.messages.insert"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/batchDelete","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/batchDelete)$","service_name":"google.gmail","resource_name":"gmail.users.messages.batchDelete"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/batchModify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/batchModify)$","service_name":"google.gmail","resource_name":"gmail.users.messages.batchModify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/import","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/import)$","service_name":"google.gmail","resource_name":"gmail.users.messages.import"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/send","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/send)$","service_name":"google.gmail","resource_name":"gmail.users.messages.send"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/{id}/modify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modify)$","service_name":"google.gmail","resource_name":"gmail.users.messages.modify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/{id}/trash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trash)$","service_name":"google.gmail","resource_name":"gmail.users.messages.trash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/{id}/untrash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/untrash)$","service_name":"google.gmail","resource_name":"gmail.users.messages.untrash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/identities","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}:disable","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.disable"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}:enable","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.enable"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}:obliterate","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::obliterate)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.obliterate"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/delegates","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates)$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/filters","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters)$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses)$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.insert"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo/{id}/setDefault","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefault)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.setDefault"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/verify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verify)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.verify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/stop","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.gmail","resource_name":"gmail.users.stop"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/threads/{id}/modify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modify)$","service_name":"google.gmail","resource_name":"gmail.users.threads.modify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/threads/{id}/trash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trash)$","service_name":"google.gmail","resource_name":"gmail.users.threads.trash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/threads/{id}/untrash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/untrash)$","service_name":"google.gmail","resource_name":"gmail.users.threads.untrash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/watch","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.gmail","resource_name":"gmail.users.watch"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/drafts/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.drafts.update"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.update"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/autoForwarding","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/autoForwarding)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateAutoForwarding"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/imap","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/imap)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateImap"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/language","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/language)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateLanguage"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/pop","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/pop)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updatePop"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.update"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/vacation","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/vacation)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateVacation"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains","path_regex":"^(?:/v1/domains)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains/{domainsId}","path_regex":"^(?:/v1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.get"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains/{domainsId}/trafficStats","path_regex":"^(?:/v1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains/{domainsId}/trafficStats/{trafficStatsId}","path_regex":"^(?:/v1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.get"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains","path_regex":"^(?:/v1beta1/domains)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains/{domainsId}","path_regex":"^(?:/v1beta1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.get"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains/{domainsId}/trafficStats","path_regex":"^(?:/v1beta1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains/{domainsId}/trafficStats/{trafficStatsId}","path_regex":"^(?:/v1beta1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.get"},{"hostname":"groupsmigration.googleapis.com","http_method":"POST","path_template":"/groups/v1/groups/{groupId}/archive","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archive)$","service_name":"google.groupsmigration","resource_name":"groupsmigration.archive.insert"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.deleteRevision"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/$purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$purge)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-purge"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalDelete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/$purge","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$purge)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-purge"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:deleteRevision","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.deleteRevision"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalDelete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/$purge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$purge)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-purge"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.delete"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.listRevisions"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/series","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForStudies"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveStudy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveInstance"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveFrames"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}/rendered","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/rendered","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Patient/{PatientId}/$everything","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Patient/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$everything)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Patient-everything"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.history"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history/{_historyId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.vread"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getFHIRStoreMetrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getFHIRStoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getFHIRStoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/instances","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/series","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.searchForStudies"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.retrieveStudy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/instances","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.metadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.retrieveSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.retrieveInstance"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.frames.retrieveFrames"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}/rendered","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.frames.rendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.metadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/rendered","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.rendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.metadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Observation/$lastn","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Observation/\\$lastn)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Observation-lastn"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Patient/{PatientId}/$everything","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Patient/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$everything)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Patient-everything"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.history"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history/{_historyId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.vread"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:listRevisions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.listRevisions"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/series","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForStudies"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveStudy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveInstance"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveFrames"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}/rendered","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/rendered","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/$references","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/\\$references)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-incoming-references"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/ConceptMap/$translate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/ConceptMap/\\$translate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.ConceptMap-search-translate"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/ConceptMap/{ConceptMapId}/$translate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/ConceptMap/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$translate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.ConceptMap-translate"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Observation/$lastn","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Observation/\\$lastn)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Observation-lastn"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Patient/{PatientId}/$everything","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Patient/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$everything)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Patient-everything"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.history"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history/{_historyId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.vread"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getFHIRStoreMetrics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getFHIRStoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getFHIRStoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:batchGet","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:batchGet)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.batchGet"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalPatch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalPatch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.patch"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:activate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.activate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:reject","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.reject"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:revoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.revoke"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}:archive","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.archive"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:checkDataAccess","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkDataAccess)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.checkDataAccess"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:evaluateUserConsents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateUserConsents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.evaluateUserConsents"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:queryAccessibleData","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAccessibleData)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.queryAccessibleData"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:deidentify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.executeBundle"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/_search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/$validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$validate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-validate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{resourceType}/_search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search-type"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:deidentify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:ingest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:ingest)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.ingest"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.cancel"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:deidentify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/nlp:analyzeEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/nlp:analyzeEntities)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.services.nlp.analyzeEntities"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:export","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:import","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.executeBundle"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/_search","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:export","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:import","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:ingest","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:ingest)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.ingest"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:deidentify","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:evaluate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.evaluate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:activate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.activate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:reject","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.reject"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:revoke","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.revoke"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}:archive","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.archive"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:checkDataAccess","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkDataAccess)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.checkDataAccess"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:evaluateUserConsents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateUserConsents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.evaluateUserConsents"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:queryAccessibleData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAccessibleData)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.queryAccessibleData"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:deidentify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.executeBundle"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/_search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.createResource"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/$validate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$validate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-validate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{resourceType}/_search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search-type"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:configureSearch","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureSearch)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.configureSearch"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:deidentify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:ingest","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:ingest)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.ingest"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.cancel"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:deidentify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/services/nlp:analyzeEntities","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/nlp:analyzeEntities)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.services.nlp.analyzeEntities"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.update"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalUpdate"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.update"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalUpdate"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.update"},{"hostname":"homegraph.googleapis.com","http_method":"DELETE","path_template":"/v1/agentUsers/{agentUsersId}","path_regex":"^(?:/v1/agentUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.homegraph","resource_name":"homegraph.agentUsers.delete"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:query","path_regex":"^(?:/v1/devices:query)$","service_name":"google.homegraph","resource_name":"homegraph.devices.query"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:reportStateAndNotification","path_regex":"^(?:/v1/devices:reportStateAndNotification)$","service_name":"google.homegraph","resource_name":"homegraph.devices.reportStateAndNotification"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:requestSync","path_regex":"^(?:/v1/devices:requestSync)$","service_name":"google.homegraph","resource_name":"homegraph.devices.requestSync"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:sync","path_regex":"^(?:/v1/devices:sync)$","service_name":"google.homegraph","resource_name":"homegraph.devices.sync"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/subjects/{subjectsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.subjects.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.organizations.roles.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/roles/{rolesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.roles.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.delete"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/subjects/{subjectsId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.subjects.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/roles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.organizations.roles.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.organizations.roles.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/roles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.projects.roles.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/roles/{rolesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.roles.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/roles","path_regex":"^(?:/v1/roles)$","service_name":"google.iam","resource_name":"iam.roles.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/roles/{rolesId}","path_regex":"^(?:/v1/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.roles.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.listPolicies"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}/operations/{operationsId}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2beta/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.listPolicies"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}/operations/{operationsId}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.operations.get"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.organizations.roles.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/roles/{rolesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.roles.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.patch"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/iamPolicies:lintPolicy","path_regex":"^(?:/v1/iamPolicies:lintPolicy)$","service_name":"google.iam","resource_name":"iam.iamPolicies.lintPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/iamPolicies:queryAuditableServices","path_regex":"^(?:/v1/iamPolicies:queryAuditableServices)$","service_name":"google.iam","resource_name":"iam.iamPolicies.queryAuditableServices"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/subjects/{subjectsId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.subjects.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:getIamPolicy","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.getIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:setIamPolicy","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.setIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:testIamPermissions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.testIamPermissions"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/roles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.organizations.roles.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}:undelete","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.organizations.roles.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/permissions:queryTestablePermissions","path_regex":"^(?:/v1/permissions:queryTestablePermissions)$","service_name":"google.iam","resource_name":"iam.permissions.queryTestablePermissions"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/roles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.projects.roles.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/roles/{rolesId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.roles.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.disable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.enable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys:upload)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.upload"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.disable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.enable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.getIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.setIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signBlob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signBlob)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.signBlob"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signJwt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signJwt)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.signJwt"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.testIamPermissions"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/roles:queryGrantableRoles","path_regex":"^(?:/v1/roles:queryGrantableRoles)$","service_name":"google.iam","resource_name":"iam.roles.queryGrantableRoles"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v2/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.createPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v2beta/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.createPolicy"},{"hostname":"iam.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.update"},{"hostname":"iam.googleapis.com","http_method":"PUT","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.update"},{"hostname":"iam.googleapis.com","http_method":"PUT","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.update"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:generateAccessToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAccessToken)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.generateAccessToken"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:generateIdToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateIdToken)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.generateIdToken"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signBlob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signBlob)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.signBlob"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signJwt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signJwt)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.signJwt"},{"hostname":"iap.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients/{identityAwareProxyClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.delete"},{"hostname":"iap.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups/{destGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.delete"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands)$","service_name":"google.iap","resource_name":"iap.projects.brands.list"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands/{brandsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.brands.get"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients)$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.list"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients/{identityAwareProxyClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.get"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups)$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.list"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups/{destGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.get"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}:iapSettings","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::iapSettings)$","service_name":"google.iap","resource_name":"iap.getIapSettings"},{"hostname":"iap.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups/{destGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.patch"},{"hostname":"iap.googleapis.com","http_method":"PATCH","path_template":"/v1/{v1Id}:iapSettings","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::iapSettings)$","service_name":"google.iap","resource_name":"iap.updateIapSettings"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/brands","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands)$","service_name":"google.iap","resource_name":"iap.projects.brands.create"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients)$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.create"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients/{identityAwareProxyClientsId}:resetSecret","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetSecret)$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.resetSecret"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups)$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.create"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:getIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iap","resource_name":"iap.getIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:setIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iap","resource_name":"iap.setIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:testIamPermissions","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iap","resource_name":"iap.testIamPermissions"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:getIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iap","resource_name":"iap.getIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:setIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iap","resource_name":"iap.setIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:testIamPermissions","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iap","resource_name":"iap.testIamPermissions"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1alpha/ideas","path_regex":"^(?:/v1alpha/ideas)$","service_name":"google.ideahub","resource_name":"ideahub.ideas.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/ideas","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideas)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideas.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/locales","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locales)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.locales.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/ideas","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideas)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideas.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/locales","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locales)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.locales.list"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/ideaStates/{ideaStatesId}","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/topicStates/{topicStatesId}","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topicStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.topicStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/ideaStates/{ideaStatesId}","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/topicStates/{topicStatesId}","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topicStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.topicStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"POST","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/ideaActivities","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaActivities)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaActivities.create"},{"hostname":"ideahub.googleapis.com","http_method":"POST","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/ideaActivities","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaActivities)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaActivities.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getProjects"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/accounts:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchGet)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.batchGet"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchGet)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.batchGet"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/publicKeys","path_regex":"^(?:/v1/publicKeys)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getPublicKeys"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/recaptchaParams","path_regex":"^(?:/v1/recaptchaParams)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getRecaptchaParams"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/sessionCookiePublicKeys","path_regex":"^(?:/v1/sessionCookiePublicKeys)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getSessionCookiePublicKeys"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/defaultSupportedIdps","path_regex":"^(?:/v2/defaultSupportedIdps)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.defaultSupportedIdps.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/config","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.getConfig"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/recaptchaConfig","path_regex":"^(?:/v2/recaptchaConfig)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getRecaptchaConfig"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/config","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.updateConfig"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:createAuthUri","path_regex":"^(?:/v1/accounts:createAuthUri)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.createAuthUri"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:delete","path_regex":"^(?:/v1/accounts:delete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:issueSamlResponse","path_regex":"^(?:/v1/accounts:issueSamlResponse)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.issueSamlResponse"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:lookup","path_regex":"^(?:/v1/accounts:lookup)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.lookup"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:resetPassword","path_regex":"^(?:/v1/accounts:resetPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.resetPassword"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:sendOobCode","path_regex":"^(?:/v1/accounts:sendOobCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.sendOobCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:sendVerificationCode","path_regex":"^(?:/v1/accounts:sendVerificationCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.sendVerificationCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithCustomToken","path_regex":"^(?:/v1/accounts:signInWithCustomToken)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithCustomToken"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithEmailLink","path_regex":"^(?:/v1/accounts:signInWithEmailLink)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithEmailLink"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithGameCenter","path_regex":"^(?:/v1/accounts:signInWithGameCenter)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithGameCenter"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithIdp","path_regex":"^(?:/v1/accounts:signInWithIdp)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithIdp"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithPassword","path_regex":"^(?:/v1/accounts:signInWithPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithPassword"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithPhoneNumber","path_regex":"^(?:/v1/accounts:signInWithPhoneNumber)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithPhoneNumber"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signUp","path_regex":"^(?:/v1/accounts:signUp)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signUp"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:update","path_regex":"^(?:/v1/accounts:update)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.update"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:verifyIosClient","path_regex":"^(?:/v1/accounts:verifyIosClient)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.verifyIosClient"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchCreate)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.batchCreate"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchDelete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.batchDelete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:delete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:lookup)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.lookup"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:query)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.query"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:sendOobCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:sendOobCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.sendOobCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:update","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:update)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.update"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchCreate)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.batchCreate"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchDelete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.batchDelete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:delete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:lookup)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.lookup"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:query)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.query"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:sendOobCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:sendOobCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.sendOobCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:update","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:update)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.update"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}:createSessionCookie","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::createSessionCookie)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.createSessionCookie"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:createSessionCookie","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::createSessionCookie)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.createSessionCookie"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:queryAccounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAccounts)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.queryAccounts"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaEnrollment:finalize","path_regex":"^(?:/v2/accounts/mfaEnrollment:finalize)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaEnrollment.finalize"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaEnrollment:start","path_regex":"^(?:/v2/accounts/mfaEnrollment:start)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaEnrollment.start"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaEnrollment:withdraw","path_regex":"^(?:/v2/accounts/mfaEnrollment:withdraw)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaEnrollment.withdraw"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaSignIn:finalize","path_regex":"^(?:/v2/accounts/mfaSignIn:finalize)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaSignIn.finalize"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaSignIn:start","path_regex":"^(?:/v2/accounts/mfaSignIn:start)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaSignIn.start"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/passkeyEnrollment:finalize","path_regex":"^(?:/v2/accounts/passkeyEnrollment:finalize)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.passkeyEnrollment.finalize"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/passkeyEnrollment:start","path_regex":"^(?:/v2/accounts/passkeyEnrollment:start)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.passkeyEnrollment.start"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/passkeySignIn:finalize","path_regex":"^(?:/v2/accounts/passkeySignIn:finalize)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.passkeySignIn.finalize"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/passkeySignIn:start","path_regex":"^(?:/v2/accounts/passkeySignIn:start)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.passkeySignIn.start"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts:revokeToken","path_regex":"^(?:/v2/accounts:revokeToken)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.revokeToken"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/identityPlatform:initializeAuth","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityPlatform:initializeAuth)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.identityPlatform.initializeAuth"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.getIamPolicy"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.setIamPolicy"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.testIamPermissions"},{"hostname":"ids.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.delete"},{"hostname":"ids.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.delete"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.ids","resource_name":"ids.projects.locations.list"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.get"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.list"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.get"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.getIamPolicy"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.list"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.get"},{"hostname":"ids.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.patch"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.create"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.setIamPolicy"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.testIamPermissions"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.cancel"},{"hostname":"indexing.googleapis.com","http_method":"GET","path_template":"/v3/urlNotifications/metadata","path_regex":"^(?:/v3/urlNotifications/metadata)$","service_name":"google.indexing","resource_name":"indexing.urlNotifications.getMetadata"},{"hostname":"indexing.googleapis.com","http_method":"POST","path_template":"/v3/urlNotifications:publish","path_regex":"^(?:/v3/urlNotifications:publish)$","service_name":"google.indexing","resource_name":"indexing.urlNotifications.publish"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/callback:generateToken","path_regex":"^(?:/v1/callback:generateToken)$","service_name":"google.integrations","resource_name":"integrations.callback.generateToken"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/connectorPlatformRegions:enumerate","path_regex":"^(?:/v1/connectorPlatformRegions:enumerate)$","service_name":"google.integrations","resource_name":"integrations.connectorPlatformRegions.enumerate"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/clientmetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientmetadata)$","service_name":"google.integrations","resource_name":"integrations.projects.getClientmetadata"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.getClients"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.getConnectionSchemaMetadata"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeActionSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeActionSchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeActionSchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeEntitySchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeEntitySchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeEntitySchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executionsnapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionsnapshots)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executionsnapshots.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executionsnapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionsnapshots)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executionsnapshots.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:getBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.getBundle"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}:listTaskEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTaskEntities)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.listTaskEntities"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:listTaskEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTaskEntities)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.listTaskEntities"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/callback:generateToken","path_regex":"^(?:/v1alpha/callback:generateToken)$","service_name":"google.integrations","resource_name":"integrations.callback.generateToken"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/connectorPlatformRegions:enumerate","path_regex":"^(?:/v1alpha/connectorPlatformRegions:enumerate)$","service_name":"google.integrations","resource_name":"integrations.connectorPlatformRegions.enumerate"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.getConnectionSchemaMetadata"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeActionSchemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeActionSchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeActionSchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeEntitySchemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeEntitySchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeEntitySchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrationtemplates/{integrationtemplatesId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrationtemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrationtemplates.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrationtemplates/{integrationtemplatesId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrationtemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrationtemplates.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:updateBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.updateBundle"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appsScriptProjects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appsScriptProjects:link","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects:link)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.link"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clients:deprovision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients:deprovision)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.clients.deprovision"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clients:provision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients:provision)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.clients.provision"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/cloudFunctions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloudFunctions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.cloudFunctions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:archive","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.archive"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:deactivate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.deactivate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.validate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:test","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::test)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.test"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/cloudFunctions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloudFunctions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.cloudFunctions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.cancel"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:archive","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.archive"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:deactivate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.deactivate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:takeoverEditLock","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::takeoverEditLock)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.takeoverEditLock"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.validate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:archiveBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archiveBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.archiveBundle"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:test","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::test)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.test"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}:createBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::createBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.createBundle"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appsScriptProjects","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appsScriptProjects:link","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects:link)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.link"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:takeoverEditLock","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::takeoverEditLock)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.takeoverEditLock"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.cancel"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:takeoverEditLock","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::takeoverEditLock)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.takeoverEditLock"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrationtemplates/{integrationtemplatesId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrationtemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrationtemplates.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.create"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v2/companies/{companiesId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v2/jobs/{jobsId}","path_regex":"^(?:/v2/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3p1beta1/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3p1beta1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies/{companiesId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs/{jobsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.jobs","resource_name":"jobs.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/companies/{companiesId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/companies/{companiesId}/jobs","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.companies.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/jobs","path_regex":"^(?:/v2/jobs)$","service_name":"google.jobs","resource_name":"jobs.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/jobs/{jobsId}","path_regex":"^(?:/v2/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2:complete","path_regex":"^(?:/v2:complete)$","service_name":"google.jobs","resource_name":"jobs.complete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/companies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/jobs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}:complete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.jobs","resource_name":"jobs.projects.complete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/companies","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/jobs","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.operations.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}:complete","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.jobs","resource_name":"jobs.projects.complete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.operations.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies/{companiesId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs/{jobsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}:completeQuery","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.completeQuery"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v2/companies/{companiesId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v2/jobs/{jobsId}","path_regex":"^(?:/v2/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3p1beta1/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3p1beta1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies/{companiesId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs/{jobsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.jobs","resource_name":"jobs.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs","path_regex":"^(?:/v2/jobs)$","service_name":"google.jobs","resource_name":"jobs.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:batchDelete","path_regex":"^(?:/v2/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:deleteByFilter","path_regex":"^(?:/v2/jobs:deleteByFilter)$","service_name":"google.jobs","resource_name":"jobs.jobs.deleteByFilter"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:histogram","path_regex":"^(?:/v2/jobs:histogram)$","service_name":"google.jobs","resource_name":"jobs.jobs.histogram"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:search","path_regex":"^(?:/v2/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:searchForAlert","path_regex":"^(?:/v2/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.jobs.searchForAlert"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/clientEvents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientEvents)$","service_name":"google.jobs","resource_name":"jobs.projects.clientEvents.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/companies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs:batchDelete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs:search","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs:searchForAlert","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.searchForAlert"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/clientEvents","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientEvents)$","service_name":"google.jobs","resource_name":"jobs.projects.clientEvents.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/companies","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs:batchDelete","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs:search","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs:searchForAlert","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.searchForAlert"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/clientEvents","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientEvents)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.clientEvents.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:batchCreate","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchCreate)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.batchCreate"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:batchDelete","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:batchUpdate","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchUpdate)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.batchUpdate"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:search","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:searchForAlert","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.searchForAlert"},{"hostname":"keep.googleapis.com","http_method":"DELETE","path_template":"/v1/notes/{notesId}","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.keep","resource_name":"keep.notes.delete"},{"hostname":"keep.googleapis.com","http_method":"GET","path_template":"/v1/notes","path_regex":"^(?:/v1/notes)$","service_name":"google.keep","resource_name":"keep.notes.list"},{"hostname":"keep.googleapis.com","http_method":"GET","path_template":"/v1/notes/{notesId}","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.keep","resource_name":"keep.notes.get"},{"hostname":"keep.googleapis.com","http_method":"GET","path_template":"/v1/notes/{notesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.keep","resource_name":"keep.media.download"},{"hostname":"keep.googleapis.com","http_method":"POST","path_template":"/v1/notes","path_regex":"^(?:/v1/notes)$","service_name":"google.keep","resource_name":"keep.notes.create"},{"hostname":"keep.googleapis.com","http_method":"POST","path_template":"/v1/notes/{notesId}/permissions:batchCreate","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchCreate)$","service_name":"google.keep","resource_name":"keep.notes.permissions.batchCreate"},{"hostname":"keep.googleapis.com","http_method":"POST","path_template":"/v1/notes/{notesId}/permissions:batchDelete","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.keep","resource_name":"keep.notes.permissions.batchDelete"},{"hostname":"kgsearch.googleapis.com","http_method":"GET","path_template":"/v1/entities:search","path_regex":"^(?:/v1/entities:search)$","service_name":"google.kgsearch","resource_name":"kgsearch.entities.search"},{"hostname":"kmsinventory.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/protectedResources:search","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/protectedResources:search)$","service_name":"google.kmsinventory","resource_name":"kmsinventory.organizations.protectedResources.search"},{"hostname":"kmsinventory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/cryptoKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys)$","service_name":"google.kmsinventory","resource_name":"kmsinventory.projects.cryptoKeys.list"},{"hostname":"kmsinventory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/protectedResourcesSummary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/protectedResourcesSummary)$","service_name":"google.kmsinventory","resource_name":"kmsinventory.projects.locations.keyRings.cryptoKeys.getProtectedResourcesSummary"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeEntities","path_regex":"^(?:/v1/documents:analyzeEntities)$","service_name":"google.language","resource_name":"language.documents.analyzeEntities"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeEntitySentiment","path_regex":"^(?:/v1/documents:analyzeEntitySentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeEntitySentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeSentiment","path_regex":"^(?:/v1/documents:analyzeSentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeSentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeSyntax","path_regex":"^(?:/v1/documents:analyzeSyntax)$","service_name":"google.language","resource_name":"language.documents.analyzeSyntax"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:annotateText","path_regex":"^(?:/v1/documents:annotateText)$","service_name":"google.language","resource_name":"language.documents.annotateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:classifyText","path_regex":"^(?:/v1/documents:classifyText)$","service_name":"google.language","resource_name":"language.documents.classifyText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:analyzeEntities","path_regex":"^(?:/v1beta1/documents:analyzeEntities)$","service_name":"google.language","resource_name":"language.documents.analyzeEntities"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:analyzeSentiment","path_regex":"^(?:/v1beta1/documents:analyzeSentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeSentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:analyzeSyntax","path_regex":"^(?:/v1beta1/documents:analyzeSyntax)$","service_name":"google.language","resource_name":"language.documents.analyzeSyntax"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:annotateText","path_regex":"^(?:/v1beta1/documents:annotateText)$","service_name":"google.language","resource_name":"language.documents.annotateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeEntities","path_regex":"^(?:/v1beta2/documents:analyzeEntities)$","service_name":"google.language","resource_name":"language.documents.analyzeEntities"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeEntitySentiment","path_regex":"^(?:/v1beta2/documents:analyzeEntitySentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeEntitySentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeSentiment","path_regex":"^(?:/v1beta2/documents:analyzeSentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeSentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeSyntax","path_regex":"^(?:/v1beta2/documents:analyzeSyntax)$","service_name":"google.language","resource_name":"language.documents.analyzeSyntax"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:annotateText","path_regex":"^(?:/v1beta2/documents:annotateText)$","service_name":"google.language","resource_name":"language.documents.annotateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:classifyText","path_regex":"^(?:/v1beta2/documents:classifyText)$","service_name":"google.language","resource_name":"language.documents.classifyText"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves","path_regex":"^(?:/v1/shelves)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.list"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves/{shelvesId}","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.get"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves/{shelvesId}/books","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.list"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves/{shelvesId}/books/{booksId}","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.get"},{"hostname":"libraryagent.googleapis.com","http_method":"POST","path_template":"/v1/shelves/{shelvesId}/books/{booksId}:borrow","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::borrow)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.borrow"},{"hostname":"libraryagent.googleapis.com","http_method":"POST","path_template":"/v1/shelves/{shelvesId}/books/{booksId}:return","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::return)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.return"},{"hostname":"licensing.googleapis.com","http_method":"DELETE","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.delete"},{"hostname":"licensing.googleapis.com","http_method":"GET","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.get"},{"hostname":"licensing.googleapis.com","http_method":"GET","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/users","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.listForProductAndSku"},{"hostname":"licensing.googleapis.com","http_method":"GET","path_template":"/apps/licensing/v1/product/{productId}/users","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.listForProduct"},{"hostname":"licensing.googleapis.com","http_method":"PATCH","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.patch"},{"hostname":"licensing.googleapis.com","http_method":"POST","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user)$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.insert"},{"hostname":"licensing.googleapis.com","http_method":"PUT","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.update"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.list"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.get"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.operations.list"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.operations.get"},{"hostname":"lifesciences.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.operations.cancel"},{"hostname":"lifesciences.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/pipelines:run","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines:run)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.pipelines.run"},{"hostname":"localservices.googleapis.com","http_method":"GET","path_template":"/v1/accountReports:search","path_regex":"^(?:/v1/accountReports:search)$","service_name":"google.localservices","resource_name":"localservices.accountReports.search"},{"hostname":"localservices.googleapis.com","http_method":"GET","path_template":"/v1/detailedLeadReports:search","path_regex":"^(?:/v1/detailedLeadReports:search)$","service_name":"google.localservices","resource_name":"localservices.detailedLeadReports.search"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/logs/{logsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/logs/{logsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/logs/{logsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/logs/{logsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/logs/{logsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/sinks/{sinksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices)$","service_name":"google.logging","resource_name":"logging.projects.logServices.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/indexes","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.logging","resource_name":"logging.projects.logServices.indexes.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logs","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.projects.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/cmekSettings","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.billingAccounts.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/logs","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.billingAccounts.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/settings","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.billingAccounts.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/cmekSettings","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.folders.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/exclusions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.folders.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.folders.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.folders.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/logs","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.folders.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/settings","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.folders.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/sinks","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.folders.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/monitoredResourceDescriptors","path_regex":"^(?:/v2/monitoredResourceDescriptors)$","service_name":"google.logging","resource_name":"logging.monitoredResourceDescriptors.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/cmekSettings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.organizations.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/exclusions","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.organizations.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.organizations.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/logs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.organizations.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/settings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.organizations.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/sinks","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.organizations.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/cmekSettings","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.projects.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/exclusions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.projects.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.projects.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.projects.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/logs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.projects.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/metrics","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/settings","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.projects.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/sinks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cmekSettings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/exclusions","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/operations","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/logs","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/settings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/sinks","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/sinks/{sinksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/monitoredResourceDescriptors","path_regex":"^(?:/v2beta1/monitoredResourceDescriptors)$","service_name":"google.logging","resource_name":"logging.monitoredResourceDescriptors.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/metrics","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/sinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/settings","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.folders.updateSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/cmekSettings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.organizations.updateCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/settings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.organizations.updateSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/cmekSettings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.updateCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/settings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.updateSettings"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/entries:write","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries:write)$","service_name":"google.logging","resource_name":"logging.projects.logs.entries.write"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:copy","path_regex":"^(?:/v2/entries:copy)$","service_name":"google.logging","resource_name":"logging.entries.copy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:list","path_regex":"^(?:/v2/entries:list)$","service_name":"google.logging","resource_name":"logging.entries.list"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:tail","path_regex":"^(?:/v2/entries:tail)$","service_name":"google.logging","resource_name":"logging.entries.tail"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:write","path_regex":"^(?:/v2/entries:write)$","service_name":"google.logging","resource_name":"logging.entries.write"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/exclusions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.folders.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.folders.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/sinks","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.folders.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/exclusions","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.organizations.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/sinks","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.organizations.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/exclusions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.projects.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.projects.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/metrics","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/sinks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/exclusions","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/sinks","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/entries:list","path_regex":"^(?:/v2beta1/entries:list)$","service_name":"google.logging","resource_name":"logging.entries.list"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/entries:write","path_regex":"^(?:/v2beta1/entries:write)$","service_name":"google.logging","resource_name":"logging.entries.write"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/metrics","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/sinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/{v2Id}/{v2Id1}/sinks/{sinksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2beta1/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2beta1/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.update"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations/{sqlIntegrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations/{sqlIntegrationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations/{sqlIntegrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.updateLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.updateLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.updateLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:attachTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.attachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:detachTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.detachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:domainJoinMachine","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::domainJoinMachine)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.domainJoinMachine"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:extendSchema","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extendSchema)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.extendSchema"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:reconfigureTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reconfigureTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.reconfigureTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:resetAdminPassword","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAdminPassword)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.resetAdminPassword"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.restore"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:validateTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.validateTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.cancel"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:attachTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.attachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:checkMigrationPermission","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkMigrationPermission)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.checkMigrationPermission"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:detachTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.detachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:disableMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.disableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:domainJoinMachine","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::domainJoinMachine)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.domainJoinMachine"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:enableMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.enableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:extendSchema","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extendSchema)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.extendSchema"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:reconfigureTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reconfigureTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.reconfigureTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:resetAdminPassword","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAdminPassword)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.resetAdminPassword"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:restore","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.restore"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:validateTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.validateTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.cancel"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:attachTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.attachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:checkMigrationPermission","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkMigrationPermission)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.checkMigrationPermission"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:detachTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.detachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:disableMigration","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.disableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:domainJoinMachine","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::domainJoinMachine)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.domainJoinMachine"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:enableMigration","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.enableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:extendSchema","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extendSchema)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.extendSchema"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:reconfigureTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reconfigureTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.reconfigureTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:resetAdminPassword","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAdminPassword)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.resetAdminPassword"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:restore","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.restore"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:validateTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.validateTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.cancel"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.testIamPermissions"},{"hostname":"manufacturers.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications/{productCertificationsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.delete"},{"hostname":"manufacturers.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/products/{productsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.delete"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications)$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.list"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications/{productCertificationsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.get"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/products","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.list"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/products/{productsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.get"},{"hostname":"manufacturers.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications/{productCertificationsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.patch"},{"hostname":"manufacturers.googleapis.com","http_method":"PUT","path_template":"/v1/accounts/{accountsId}/products/{productsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.update"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.delete"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.delete"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.delete"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.delete"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.get"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.patch"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.updateParameters"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.patch"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateParameters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.updateParameters"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.create"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:applyParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.applyParameters"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.rescheduleMaintenance"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.cancel"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.create"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:applyParameters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.applyParameters"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:applySoftwareUpdate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applySoftwareUpdate)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.applySoftwareUpdate"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.rescheduleMaintenance"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.cancel"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.delete"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.patch"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.cancel"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:exportMetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.exportMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.restore"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.cancel"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/{servicesId1}:removeIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.removeIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterLocation","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterLocation)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterLocation"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:exportMetadata","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.exportMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:moveTableToDatabase","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveTableToDatabase)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.moveTableToDatabase"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:queryMetadata","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.queryMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:restore","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.restore"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.cancel"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/{servicesId1}:removeIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.removeIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterLocation","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterLocation)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterLocation"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:exportMetadata","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.exportMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:moveTableToDatabase","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveTableToDatabase)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.moveTableToDatabase"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:queryMetadata","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.queryMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:restore","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.restore"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.testIamPermissions"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles/{importDataFilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports/{reportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets/{assetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles/{importDataFilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports/{reportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.getSettings"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.updateSettings"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:aggregateValues","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:aggregateValues)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.aggregateValues"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:batchDelete","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:batchDelete)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.batchDelete"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:batchUpdate","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:batchUpdate)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.batchUpdate"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:reportAssetFrames","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:reportAssetFrames)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.reportAssetFrames"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:addAssets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addAssets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.addAssets"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:removeAssets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeAssets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.removeAssets"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}:run","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.run"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}:validate","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.validate"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.cancel"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.create"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.operations.delete"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.ml","resource_name":"ml.projects.locations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.ml","resource_name":"ml.projects.locations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.operations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ml","resource_name":"ml.projects.operations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ml","resource_name":"ml.projects.operations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.operations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.operations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}:getConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getConfig)$","service_name":"google.ml","resource_name":"ml.projects.getConfig"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}:getConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getConfig)$","service_name":"google.ml","resource_name":"ml.projects.getConfig"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.patch"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.jobs.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.jobs.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.jobs.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.jobs.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.locations.operations.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:addMeasurement","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addMeasurement)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.addMeasurement"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:checkEarlyStoppingState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkEarlyStoppingState)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.checkEarlyStoppingState"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:complete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.complete"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.stop"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:listOptimalTrials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:listOptimalTrials)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.listOptimalTrials"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:suggest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:suggest)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.suggest"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}:setDefault","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefault)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.setDefault"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}:setDefault","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefault)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.setDefault"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.models.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.models.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.operations.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.operations.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:explain","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::explain)$","service_name":"google.ml","resource_name":"ml.projects.explain"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:predict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.ml","resource_name":"ml.projects.predict"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:predict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.ml","resource_name":"ml.projects.predict"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/global/metricsScopes/{metricsScopesId}/projects/{projectsId}","path_regex":"^(?:/v1/locations/global/metricsScopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.projects.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/dashboards/{dashboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/alertPolicies/{alertPoliciesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/metricDescriptors/{metricDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs/{uptimeCheckConfigsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives/{serviceLevelObjectivesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.delete"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/locations/global/metricsScopes/{metricsScopesId}","path_regex":"^(?:/v1/locations/global/metricsScopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/locations/global/metricsScopes:listMetricsScopesByMonitoredProject","path_regex":"^(?:/v1/locations/global/metricsScopes:listMetricsScopesByMonitoredProject)$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.listMetricsScopesByMonitoredProject"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.operations.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dashboards","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards)$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dashboards/{dashboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/label/{label}/values","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/label/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.label.values"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/labels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/labels)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.labels.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/metadata)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.metadata.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/folders/{foldersId}/timeSeries","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.folders.timeSeries.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/organizations/{organizationsId}/timeSeries","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.organizations.timeSeries.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/alertPolicies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies)$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/alertPolicies/{alertPoliciesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/groups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/groups/{groupsId}/members","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.members.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/metricDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/metricDescriptors/{metricDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/monitoredResourceDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoredResourceDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.monitoredResourceDescriptors.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/monitoredResourceDescriptors/{monitoredResourceDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoredResourceDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.monitoredResourceDescriptors.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannelDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannelDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannelDescriptors.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannelDescriptors/{notificationChannelDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannelDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannelDescriptors.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannels","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/snoozes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes)$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/snoozes/{snoozesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/timeSeries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs)$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs/{uptimeCheckConfigsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/uptimeCheckIps","path_regex":"^(?:/v3/uptimeCheckIps)$","service_name":"google.monitoring","resource_name":"monitoring.uptimeCheckIps.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.monitoring","resource_name":"monitoring.services.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives)$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives/{serviceLevelObjectivesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.get"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/dashboards/{dashboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/alertPolicies/{alertPoliciesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/snoozes/{snoozesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs/{uptimeCheckConfigsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives/{serviceLevelObjectivesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.patch"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/locations/global/metricsScopes/{metricsScopesId}/projects","path_regex":"^(?:/v1/locations/global/metricsScopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.projects.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/dashboards","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards)$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/labels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/labels)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.labels"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/query)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.query"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/query_exemplars","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/query_exemplars)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.query_exemplars"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/query_range","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/query_range)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.query_range"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/series","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/series)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.series"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/alertPolicies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies)$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/collectdTimeSeries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectdTimeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.projects.collectdTimeSeries.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/groups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/metricDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}:getVerificationCode","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getVerificationCode)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.getVerificationCode"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}:sendVerificationCode","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sendVerificationCode)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.sendVerificationCode"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}:verify","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.verify"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/snoozes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes)$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/timeSeries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/timeSeries:createService","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries:createService)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.createService"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/timeSeries:query","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries:query)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.query"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs)$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/{v3Id}/{v3Id1}/services","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.monitoring","resource_name":"monitoring.services.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives)$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.create"},{"hostname":"monitoring.googleapis.com","http_method":"PUT","path_template":"/v3/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.update"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/admins/{adminsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.delete"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/admins/{adminsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.delete"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts","path_regex":"^(?:/v1/accounts)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.get"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/admins","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/invitations","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.invitations.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/admins","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.patch"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/admins/{adminsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.patch"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/admins/{adminsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.patch"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts","path_regex":"^(?:/v1/accounts)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.create"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/admins","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.create"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/invitations/{invitationsId}:accept","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.invitations.accept"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/invitations/{invitationsId}:decline","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decline)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.invitations.decline"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/admins","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.create"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:transfer","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::transfer)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.transfer"},{"hostname":"mybusinessbusinesscalls.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/businesscallsinsights","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businesscallsinsights)$","service_name":"google.mybusinessbusinesscalls","resource_name":"mybusinessbusinesscalls.locations.businesscallsinsights.list"},{"hostname":"mybusinessbusinesscalls.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/businesscallssettings","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businesscallssettings)$","service_name":"google.mybusinessbusinesscalls","resource_name":"mybusinessbusinesscalls.locations.getBusinesscallssettings"},{"hostname":"mybusinessbusinesscalls.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/businesscallssettings","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businesscallssettings)$","service_name":"google.mybusinessbusinesscalls","resource_name":"mybusinessbusinesscalls.locations.updateBusinesscallssettings"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.delete"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/locations","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.accounts.locations.list"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/attributes","path_regex":"^(?:/v1/attributes)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.attributes.list"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/categories","path_regex":"^(?:/v1/categories)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.categories.list"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/categories:batchGet","path_regex":"^(?:/v1/categories:batchGet)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.categories.batchGet"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/chains/{chainsId}","path_regex":"^(?:/v1/chains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.chains.get"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/chains:search","path_regex":"^(?:/v1/chains:search)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.chains.search"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.get"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/attributes","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.getAttributes"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/attributes:getGoogleUpdated","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes:getGoogleUpdated)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.attributes.getGoogleUpdated"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}:getGoogleUpdated","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getGoogleUpdated)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.getGoogleUpdated"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.patch"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/attributes","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.updateAttributes"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/locations","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.accounts.locations.create"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"POST","path_template":"/v1/googleLocations:search","path_regex":"^(?:/v1/googleLocations:search)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.googleLocations.search"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:associate","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::associate)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.associate"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:clearLocationAssociation","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearLocationAssociation)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.clearLocationAssociation"},{"hostname":"mybusinesslodging.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/lodging","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lodging)$","service_name":"google.mybusinesslodging","resource_name":"mybusinesslodging.locations.getLodging"},{"hostname":"mybusinesslodging.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/lodging:getGoogleUpdated","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lodging:getGoogleUpdated)$","service_name":"google.mybusinesslodging","resource_name":"mybusinesslodging.locations.lodging.getGoogleUpdated"},{"hostname":"mybusinesslodging.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/lodging","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lodging)$","service_name":"google.mybusinesslodging","resource_name":"mybusinesslodging.locations.updateLodging"},{"hostname":"mybusinessnotifications.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/notificationSetting","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationSetting)$","service_name":"google.mybusinessnotifications","resource_name":"mybusinessnotifications.accounts.getNotificationSetting"},{"hostname":"mybusinessnotifications.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/notificationSetting","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationSetting)$","service_name":"google.mybusinessnotifications","resource_name":"mybusinessnotifications.accounts.updateNotificationSetting"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/placeActionLinks/{placeActionLinksId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.delete"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/placeActionLinks","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks)$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.list"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/placeActionLinks/{placeActionLinksId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.get"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"GET","path_template":"/v1/placeActionTypeMetadata","path_regex":"^(?:/v1/placeActionTypeMetadata)$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.placeActionTypeMetadata.list"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/placeActionLinks/{placeActionLinksId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.patch"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/placeActionLinks","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks)$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.create"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/questions/{questionsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.delete"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/questions/{questionsId}/answers:delete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers:delete)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.answers.delete"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/questions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.list"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/questions/{questionsId}/answers","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.answers.list"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/questions/{questionsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.patch"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/questions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.create"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/questions/{questionsId}/answers:upsert","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers:upsert)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.answers.upsert"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/VoiceOfMerchantState","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/VoiceOfMerchantState)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.getVoiceOfMerchantState"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/verifications","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifications)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.verifications.list"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/verifications/{verificationsId}:complete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.verifications.complete"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:fetchVerificationOptions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchVerificationOptions)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.fetchVerificationOptions"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:verify","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.verify"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"POST","path_template":"/v1/verificationTokens:generate","path_regex":"^(?:/v1/verificationTokens:generate)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.verificationTokens.generate"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.cancel"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.cancel"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.testIamPermissions"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.getIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.getIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.patch"},{"hostname":"networkmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.patch"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.create"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:rerun","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rerun)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.rerun"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.setIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.testIamPermissions"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.cancel"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.create"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:rerun","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rerun)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.rerun"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.setIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.testIamPermissions"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:listReferences","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listReferences)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.listReferences"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:listReferences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listReferences)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.listReferences"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.get"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:addItems","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.addItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:cloneItems","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cloneItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.cloneItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:removeItems","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.removeItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:addItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.addItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:cloneItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cloneItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.cloneItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:removeItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.removeItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.create"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheKeysets/{edgeCacheKeysetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheKeysets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheKeysets.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheOrigins/{edgeCacheOriginsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheOrigins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheOrigins.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheServices/{edgeCacheServicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheServices.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheKeysets/{edgeCacheKeysetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheKeysets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheKeysets.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheKeysets/{edgeCacheKeysetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheKeysets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheKeysets.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheOrigins/{edgeCacheOriginsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheOrigins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheOrigins.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheOrigins/{edgeCacheOriginsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheOrigins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheOrigins.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheServices/{edgeCacheServicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheServices.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheServices/{edgeCacheServicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheServices.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.cancel"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.cancel"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.create"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.delete"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.getIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getInstanceHealth","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getInstanceHealth)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.getInstanceHealth"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:isUpgradeable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::isUpgradeable)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.isUpgradeable"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.getIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.getIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.get"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setAccelerator","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAccelerator)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setAccelerator"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setLabels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLabels)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setLabels"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setMachineType","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMachineType)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setMachineType"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateConfig)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.updateConfig"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateMetadataItems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateMetadataItems)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.updateMetadataItems"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateShieldedInstanceConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateShieldedInstanceConfig)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.updateShieldedInstanceConfig"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.patch"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:diagnose","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.diagnose"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:report","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::report)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.report"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reportEvent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportEvent)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.reportEvent"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reset","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.reset"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.rollback"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.start"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.stop"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.testIamPermissions"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.upgrade"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgradeInternal","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgradeInternal)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.upgradeInternal"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances:register","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances:register)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.register"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.cancel"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:diagnose","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.diagnose"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:refreshRuntimeTokenInternal","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refreshRuntimeTokenInternal)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.refreshRuntimeTokenInternal"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:reportEvent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportEvent)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.reportEvent"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:reset","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.reset"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.setIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.start"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.stop"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:switch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::switch)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.switch"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.testIamPermissions"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.upgrade"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}:trigger","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::trigger)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.trigger"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.testIamPermissions"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.cancel"},{"hostname":"ondemandscanning.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.delete"},{"hostname":"ondemandscanning.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.delete"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.get"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scans/{scansId}/vulnerabilities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilities)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.vulnerabilities.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.get"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/scans/{scansId}/vulnerabilities","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilities)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.vulnerabilities.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.cancel"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.wait"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scans:analyzePackages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans:analyzePackages)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.analyzePackages"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.cancel"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.wait"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/scans:analyzePackages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans:analyzePackages)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.analyzePackages"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/policies/{policiesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/customConstraints/{customConstraintsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/policies/{policiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/constraints","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/constraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.constraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/policies","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/policies/{policiesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/policies/{policiesId}:getEffectivePolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectivePolicy)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.getEffectivePolicy"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/constraints","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/constraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.constraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/customConstraints","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/customConstraints/{customConstraintsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/policies","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}:getEffectivePolicy","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectivePolicy)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.getEffectivePolicy"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/constraints","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/constraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.constraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/policies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/policies/{policiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/policies/{policiesId}:getEffectivePolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectivePolicy)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.getEffectivePolicy"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/policies/{policiesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/customConstraints/{customConstraintsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/policies/{policiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/policies","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.create"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/customConstraints","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.create"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/policies","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.create"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/policies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.create"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/guestPolicies/{guestPoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventories","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventories)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventory","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/report","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/report)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/reports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReport","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReport)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.listRevisions"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchJobs/{patchJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchJobs/{patchJobsId}/instanceDetails","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceDetails)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.instanceDetails.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instanceOSPoliciesCompliances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceOSPoliciesCompliances)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instanceOSPoliciesCompliances.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instanceOSPoliciesCompliances/{instanceOSPoliciesCompliancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceOSPoliciesCompliances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instanceOSPoliciesCompliances.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventories","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventories)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventory","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/report","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/report)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/reports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReport","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReport)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}:listRevisions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.listRevisions"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/guestPolicies","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies)$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/guestPolicies/{guestPoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchJobs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchJobs/{patchJobsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchJobs/{patchJobsId}/instanceDetails","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceDetails)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.instanceDetails.list"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/guestPolicies/{guestPoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:pause","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.pause"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.resume"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchJobs/{patchJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchJobs:execute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs:execute)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.execute"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/guestPolicies","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies)$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:pause","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.pause"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:resume","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.resume"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchJobs/{patchJobsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchJobs:execute","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs:execute)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.execute"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/zones/{zonesId}/instances/{instancesId}:lookupEffectiveGuestPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupEffectiveGuestPolicy)$","service_name":"google.osconfig","resource_name":"osconfig.projects.zones.instances.lookupEffectiveGuestPolicy"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1/users/{usersId}/projects/{projectsId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/users/{usersId}/projects/{projectsId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/users/{usersId}/projects/{projectsId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.delete"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/loginProfile","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loginProfile)$","service_name":"google.oslogin","resource_name":"oslogin.users.getLoginProfile"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.get"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1alpha/users/{usersId}/loginProfile","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loginProfile)$","service_name":"google.oslogin","resource_name":"oslogin.users.getLoginProfile"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1alpha/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.get"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1beta/users/{usersId}/loginProfile","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loginProfile)$","service_name":"google.oslogin","resource_name":"oslogin.users.getLoginProfile"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1beta/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.get"},{"hostname":"oslogin.googleapis.com","http_method":"PATCH","path_template":"/v1/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.patch"},{"hostname":"oslogin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.patch"},{"hostname":"oslogin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.patch"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/sshPublicKeys","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys)$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.create"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}:importSshPublicKey","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.importSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1alpha/users/{usersId}/sshPublicKeys","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys)$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.create"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1alpha/users/{usersId}:importSshPublicKey","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.importSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1beta/users/{usersId}/sshPublicKeys","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys)$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.create"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1beta/users/{usersId}:importSshPublicKey","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.importSshPublicKey"},{"hostname":"pagespeedonline.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v5/runPagespeed","path_regex":"^(?:/pagespeedonline/v5/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"partners.googleapis.com","http_method":"DELETE","path_template":"/v2/users/{userId}/companyRelation","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companyRelation)$","service_name":"google.partners","resource_name":"partners.users.deleteCompanyRelation"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/analytics","path_regex":"^(?:/v2/analytics)$","service_name":"google.partners","resource_name":"partners.analytics.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.partners","resource_name":"partners.companies.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/companies/{companyId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.partners","resource_name":"partners.companies.get"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/leads","path_regex":"^(?:/v2/leads)$","service_name":"google.partners","resource_name":"partners.leads.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/offers","path_regex":"^(?:/v2/offers)$","service_name":"google.partners","resource_name":"partners.offers.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/offers/history","path_regex":"^(?:/v2/offers/history)$","service_name":"google.partners","resource_name":"partners.offers.history.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/partnersstatus","path_regex":"^(?:/v2/partnersstatus)$","service_name":"google.partners","resource_name":"partners.getPartnersstatus"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/userStates","path_regex":"^(?:/v2/userStates)$","service_name":"google.partners","resource_name":"partners.userStates.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/users/{userId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.partners","resource_name":"partners.users.get"},{"hostname":"partners.googleapis.com","http_method":"PATCH","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.partners","resource_name":"partners.updateCompanies"},{"hostname":"partners.googleapis.com","http_method":"PATCH","path_template":"/v2/leads","path_regex":"^(?:/v2/leads)$","service_name":"google.partners","resource_name":"partners.updateLeads"},{"hostname":"partners.googleapis.com","http_method":"PATCH","path_template":"/v2/users/profile","path_regex":"^(?:/v2/users/profile)$","service_name":"google.partners","resource_name":"partners.users.updateProfile"},{"hostname":"partners.googleapis.com","http_method":"POST","path_template":"/v2/clientMessages:log","path_regex":"^(?:/v2/clientMessages:log)$","service_name":"google.partners","resource_name":"partners.clientMessages.log"},{"hostname":"partners.googleapis.com","http_method":"POST","path_template":"/v2/companies/{companyId}/leads","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leads)$","service_name":"google.partners","resource_name":"partners.companies.leads.create"},{"hostname":"partners.googleapis.com","http_method":"POST","path_template":"/v2/userEvents:log","path_regex":"^(?:/v2/userEvents:log)$","service_name":"google.partners","resource_name":"partners.userEvents.log"},{"hostname":"partners.googleapis.com","http_method":"PUT","path_template":"/v2/users/{userId}/companyRelation","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companyRelation)$","service_name":"google.partners","resource_name":"partners.users.createCompanyRelation"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/products","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.products.list"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/promotions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.promotions.list"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.get"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/promotions:findEligible","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions:findEligible)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.promotions.findEligible"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.create"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:cancel","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.cancel"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:entitle","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::entitle)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.entitle"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:extend","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extend)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.extend"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:undoCancel","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undoCancel)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.undoCancel"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions:provision","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions:provision)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.provision"},{"hostname":"people.googleapis.com","http_method":"DELETE","path_template":"/v1/contactGroups/{contactGroupsId}","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.contactGroups.delete"},{"hostname":"people.googleapis.com","http_method":"DELETE","path_template":"/v1/people/{peopleId}:deleteContact","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteContact)$","service_name":"google.people","resource_name":"people.people.deleteContact"},{"hostname":"people.googleapis.com","http_method":"DELETE","path_template":"/v1/people/{peopleId}:deleteContactPhoto","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteContactPhoto)$","service_name":"google.people","resource_name":"people.people.deleteContactPhoto"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/contactGroups","path_regex":"^(?:/v1/contactGroups)$","service_name":"google.people","resource_name":"people.contactGroups.list"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/contactGroups/{contactGroupsId}","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.contactGroups.get"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/contactGroups:batchGet","path_regex":"^(?:/v1/contactGroups:batchGet)$","service_name":"google.people","resource_name":"people.contactGroups.batchGet"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/otherContacts","path_regex":"^(?:/v1/otherContacts)$","service_name":"google.people","resource_name":"people.otherContacts.list"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/otherContacts:search","path_regex":"^(?:/v1/otherContacts:search)$","service_name":"google.people","resource_name":"people.otherContacts.search"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people/{peopleId}","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.people.get"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people/{peopleId}/connections","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.people","resource_name":"people.people.connections.list"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:batchGet","path_regex":"^(?:/v1/people:batchGet)$","service_name":"google.people","resource_name":"people.people.getBatchGet"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:listDirectoryPeople","path_regex":"^(?:/v1/people:listDirectoryPeople)$","service_name":"google.people","resource_name":"people.people.listDirectoryPeople"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:searchContacts","path_regex":"^(?:/v1/people:searchContacts)$","service_name":"google.people","resource_name":"people.people.searchContacts"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:searchDirectoryPeople","path_regex":"^(?:/v1/people:searchDirectoryPeople)$","service_name":"google.people","resource_name":"people.people.searchDirectoryPeople"},{"hostname":"people.googleapis.com","http_method":"PATCH","path_template":"/v1/people/{peopleId}:updateContact","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateContact)$","service_name":"google.people","resource_name":"people.people.updateContact"},{"hostname":"people.googleapis.com","http_method":"PATCH","path_template":"/v1/people/{peopleId}:updateContactPhoto","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateContactPhoto)$","service_name":"google.people","resource_name":"people.people.updateContactPhoto"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/contactGroups","path_regex":"^(?:/v1/contactGroups)$","service_name":"google.people","resource_name":"people.contactGroups.create"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/contactGroups/{contactGroupsId}/members:modify","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members:modify)$","service_name":"google.people","resource_name":"people.contactGroups.members.modify"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/otherContacts/{otherContactsId}:copyOtherContactToMyContactsGroup","path_regex":"^(?:/v1/otherContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::copyOtherContactToMyContactsGroup)$","service_name":"google.people","resource_name":"people.otherContacts.copyOtherContactToMyContactsGroup"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:batchCreateContacts","path_regex":"^(?:/v1/people:batchCreateContacts)$","service_name":"google.people","resource_name":"people.people.batchCreateContacts"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:batchDeleteContacts","path_regex":"^(?:/v1/people:batchDeleteContacts)$","service_name":"google.people","resource_name":"people.people.batchDeleteContacts"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:batchUpdateContacts","path_regex":"^(?:/v1/people:batchUpdateContacts)$","service_name":"google.people","resource_name":"people.people.batchUpdateContacts"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:createContact","path_regex":"^(?:/v1/people:createContact)$","service_name":"google.people","resource_name":"people.people.createContact"},{"hostname":"people.googleapis.com","http_method":"PUT","path_template":"/v1/contactGroups/{contactGroupsId}","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.contactGroups.update"},{"hostname":"playablelocations.googleapis.com","http_method":"POST","path_template":"/v3:logImpressions","path_regex":"^(?:/v3:logImpressions)$","service_name":"google.playablelocations","resource_name":"playablelocations.logImpressions"},{"hostname":"playablelocations.googleapis.com","http_method":"POST","path_template":"/v3:logPlayerReports","path_regex":"^(?:/v3:logPlayerReports)$","service_name":"google.playablelocations","resource_name":"playablelocations.logPlayerReports"},{"hostname":"playablelocations.googleapis.com","http_method":"POST","path_template":"/v3:samplePlayableLocations","path_regex":"^(?:/v3:samplePlayableLocations)$","service_name":"google.playablelocations","resource_name":"playablelocations.samplePlayableLocations"},{"hostname":"playcustomapp.googleapis.com","http_method":"POST","path_template":"/playcustomapp/v1/accounts/{account}/customApps","path_regex":"^(?:/playcustomapp/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customApps)$","service_name":"google.playcustomapp","resource_name":"playcustomapp.accounts.customApps.create"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/anomalies","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anomalies)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.anomalies.list"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/anrRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/crashRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/errorCountMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/errorIssues:search","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorIssues:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.issues.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/errorReports:search","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorReports:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.reports.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/excessiveWakeupRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/slowRenderingRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/slowStartRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/anomalies","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anomalies)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.anomalies.list"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/anrRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/crashRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/errorCountMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/errorIssues:search","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorIssues:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.issues.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/errorReports:search","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorReports:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.reports.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/excessiveWakeupRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/slowRenderingRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/slowStartRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/anrRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/crashRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/errorCountMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/excessiveWakeupRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/slowRenderingRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/slowStartRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/anrRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/crashRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/errorCountMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/excessiveWakeupRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/slowRenderingRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/slowStartRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.query"},{"hostname":"playintegrity.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:decodeIntegrityToken","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decodeIntegrityToken)$","service_name":"google.playintegrity","resource_name":"playintegrity.decodeIntegrityToken"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/avails","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/avails)$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.avails.list"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/avails/{availId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/avails/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.avails.get"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/orders","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.orders.list"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/orders/{orderId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.orders.get"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/storeInfos","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeInfos)$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.storeInfos.list"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/storeInfos/{videoId}/country/{country}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeInfos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/country/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.storeInfos.country.get"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.projects.locations.activityTypes.activities.query"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.projects.locations.activityTypes.activities.query"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/operations","path_regex":"^(?:/v1alpha/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/operations/{operationsId}","path_regex":"^(?:/v1alpha/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/operations","path_regex":"^(?:/v1beta/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/operations/{operationsId}","path_regex":"^(?:/v1beta/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.create"},{"hostname":"policytroubleshooter.googleapis.com","http_method":"POST","path_template":"/v1/iam:troubleshoot","path_regex":"^(?:/v1/iam:troubleshoot)$","service_name":"google.policytroubleshooter","resource_name":"policytroubleshooter.iam.troubleshoot"},{"hostname":"policytroubleshooter.googleapis.com","http_method":"POST","path_template":"/v1beta/iam:troubleshoot","path_regex":"^(?:/v1beta/iam:troubleshoot)$","service_name":"google.policytroubleshooter","resource_name":"policytroubleshooter.iam.troubleshoot"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/assets","path_regex":"^(?:/v1/assets)$","service_name":"google.poly","resource_name":"poly.assets.list"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/assets/{assetsId}","path_regex":"^(?:/v1/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.poly","resource_name":"poly.assets.get"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/assets","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.poly","resource_name":"poly.users.assets.list"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/likedassets","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/likedassets)$","service_name":"google.poly","resource_name":"poly.users.likedassets.list"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.delete"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:fetch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetch)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.fetch"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.certificateRevocationLists.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reusableConfigs/{reusableConfigsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reusableConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.reusableConfigs.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.patch"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:activate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.activate"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.disable"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.enable"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.undelete"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates/{certificatesId}:revoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.revoke"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:fetchCaCerts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchCaCerts)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.fetchCaCerts"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.cancel"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.certificateRevocationLists.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.certificateRevocationLists.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.cancel"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reusableConfigs/{reusableConfigsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reusableConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.reusableConfigs.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reusableConfigs/{reusableConfigsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reusableConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.reusableConfigs.testIamPermissions"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers","path_regex":"^(?:/v1alpha1/customers)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.updateSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.updateSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.updateSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.signDevice"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.deployments.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:provisionDeployment","path_regex":"^(?:/v1alpha1/customers:provisionDeployment)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.provisionDeployment"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.signDevice"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:generateSecret","path_regex":"^(?:/v1alpha1/installer:generateSecret)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.installer.generateSecret"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:validate","path_regex":"^(?:/v1alpha1/installer:validate)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.installer.validate"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.signDevice"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.deployments.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:get","path_regex":"^(?:/v1alpha1/policies:get)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.policies.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:set","path_regex":"^(?:/v1alpha1/policies:set)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.policies.set"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:test","path_regex":"^(?:/v1alpha1/policies:test)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.policies.test"},{"hostname":"proximitybeacon.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/beacons/{beaconsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.delete"},{"hostname":"proximitybeacon.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/beacons/{beaconsId}/attachments/{attachmentsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.delete"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons","path_regex":"^(?:/v1beta1/beacons)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons/{beaconsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.get"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons/{beaconsId}/attachments","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons/{beaconsId}/diagnostics","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diagnostics)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.diagnostics.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/eidparams","path_regex":"^(?:/v1beta1/eidparams)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.getEidparams"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/namespaces","path_regex":"^(?:/v1beta1/namespaces)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.namespaces.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beaconinfo:getforobserved","path_regex":"^(?:/v1beta1/beaconinfo:getforobserved)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beaconinfo.getforobserved"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}/attachments","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.create"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}/attachments:batchDelete","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments:batchDelete)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.batchDelete"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}:activate","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.activate"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}:deactivate","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.deactivate"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}:decommission","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decommission)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.decommission"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons:register","path_regex":"^(?:/v1beta1/beacons:register)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.register"},{"hostname":"proximitybeacon.googleapis.com","http_method":"PUT","path_template":"/v1beta1/beacons/{beaconsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.update"},{"hostname":"proximitybeacon.googleapis.com","http_method":"PUT","path_template":"/v1beta1/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.namespaces.update"},{"hostname":"publicca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/externalAccountKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccountKeys)$","service_name":"google.publicca","resource_name":"publicca.projects.locations.externalAccountKeys.create"},{"hostname":"publicca.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/externalAccountKeys","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccountKeys)$","service_name":"google.publicca","resource_name":"publicca.projects.locations.externalAccountKeys.create"},{"hostname":"publicca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/externalAccountKeys","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccountKeys)$","service_name":"google.publicca","resource_name":"publicca.projects.locations.externalAccountKeys.create"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.deleteRevision"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1a/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta1a/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1a/topics/{topicsId}","path_regex":"^(?:/v1beta1a/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.topics.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.delete"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.listRevisions"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/subscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.snapshots.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}/subscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/subscriptions","path_regex":"^(?:/v1beta1a/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta1a/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/topics","path_regex":"^(?:/v1beta1a/topics)$","service_name":"google.pubsub","resource_name":"pubsub.topics.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/topics/{topicsId}","path_regex":"^(?:/v1beta1a/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.topics.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/subscriptions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}/subscriptions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.patch"},{"hostname":"pubsub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.patch"},{"hostname":"pubsub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.patch"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.create"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.commit"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.rollback"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas:validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas:validate)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.validate"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas:validateMessage","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas:validateMessage)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.validateMessage"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:acknowledge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.acknowledge"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:detach","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detach)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.detach"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyAckDeadline","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAckDeadline)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyAckDeadline"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyPushConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyPushConfig)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyPushConfig"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:pull","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pull)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.pull"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:seek","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::seek)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.seek"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:publish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.publish"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions","path_regex":"^(?:/v1beta1a/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.create"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/acknowledge","path_regex":"^(?:/v1beta1a/subscriptions/acknowledge)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.acknowledge"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/modifyAckDeadline","path_regex":"^(?:/v1beta1a/subscriptions/modifyAckDeadline)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.modifyAckDeadline"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/modifyPushConfig","path_regex":"^(?:/v1beta1a/subscriptions/modifyPushConfig)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.modifyPushConfig"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/pull","path_regex":"^(?:/v1beta1a/subscriptions/pull)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.pull"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/pullBatch","path_regex":"^(?:/v1beta1a/subscriptions/pullBatch)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.pullBatch"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/topics","path_regex":"^(?:/v1beta1a/topics)$","service_name":"google.pubsub","resource_name":"pubsub.topics.create"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/topics/publish","path_regex":"^(?:/v1beta1a/topics/publish)$","service_name":"google.pubsub","resource_name":"pubsub.topics.publish"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/topics/publishBatch","path_regex":"^(?:/v1beta1a/topics/publishBatch)$","service_name":"google.pubsub","resource_name":"pubsub.topics.publishBatch"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:acknowledge","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.acknowledge"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyAckDeadline","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAckDeadline)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyAckDeadline"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyPushConfig","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyPushConfig)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyPushConfig"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:pull","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pull)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.pull"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:publish","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.publish"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.create"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/topics","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.topics.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}/partitions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.getPartitions"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}/subscriptions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.subscriptions.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/cursor/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}/cursors","path_regex":"^(?:/v1/cursor/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cursors)$","service_name":"google.pubsublite","resource_name":"pubsublite.cursor.projects.locations.subscriptions.cursors.list"},{"hostname":"pubsublite.googleapis.com","http_method":"PATCH","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.patch"},{"hostname":"pubsublite.googleapis.com","http_method":"PATCH","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.patch"},{"hostname":"pubsublite.googleapis.com","http_method":"PATCH","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.patch"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.cancel"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.create"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.create"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:seek","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::seek)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.seek"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.create"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/cursor/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:commitCursor","path_regex":"^(?:/v1/cursor/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commitCursor)$","service_name":"google.pubsublite","resource_name":"pubsublite.cursor.projects.locations.subscriptions.commitCursor"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/topicStats/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}:computeHeadCursor","path_regex":"^(?:/v1/topicStats/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeHeadCursor)$","service_name":"google.pubsublite","resource_name":"pubsublite.topicStats.projects.locations.topics.computeHeadCursor"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/topicStats/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}:computeMessageStats","path_regex":"^(?:/v1/topicStats/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeMessageStats)$","service_name":"google.pubsublite","resource_name":"pubsublite.topicStats.projects.locations.topics.computeMessageStats"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/topicStats/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}:computeTimeCursor","path_regex":"^(?:/v1/topicStats/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeTimeCursor)$","service_name":"google.pubsublite","resource_name":"pubsublite.topicStats.projects.locations.topics.computeTimeCursor"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"DELETE","path_template":"/v1/publications/{publicationsId}/readers/{readersId}","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.delete"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"GET","path_template":"/v1/publications/{publicationsId}/readers/{readersId}","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.get"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"GET","path_template":"/v1/publications/{publicationsId}/readers/{readersId}/entitlements","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.getEntitlements"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"PATCH","path_template":"/v1/publications/{publicationsId}/readers/{readersId}/entitlements","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.updateEntitlements"},{"hostname":"realtimebidding.googleapis.com","http_method":"DELETE","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.delete"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders","path_regex":"^(?:/v1/bidders)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/creatives","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.creatives.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/endpoints","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.endpoints.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.endpoints.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/publisherConnections","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/publisherConnections/{publisherConnectionsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers","path_regex":"^(?:/v1/buyers)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/creatives","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/creatives/{creativesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/userLists","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}:getRemarketingTag","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getRemarketingTag)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.getRemarketingTag"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}:getRemarketingTag","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getRemarketingTag)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.getRemarketingTag"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"PATCH","path_template":"/v1/bidders/{biddersId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.endpoints.patch"},{"hostname":"realtimebidding.googleapis.com","http_method":"PATCH","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.patch"},{"hostname":"realtimebidding.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/creatives/{creativesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.patch"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/creatives:watch","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives:watch)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.creatives.watch"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:activate","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.activate"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:addTargetedApps","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTargetedApps)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.addTargetedApps"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:addTargetedPublishers","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTargetedPublishers)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.addTargetedPublishers"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:addTargetedSites","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTargetedSites)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.addTargetedSites"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:removeTargetedApps","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeTargetedApps)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.removeTargetedApps"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:removeTargetedPublishers","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeTargetedPublishers)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.removeTargetedPublishers"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:removeTargetedSites","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeTargetedSites)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.removeTargetedSites"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:suspend","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::suspend)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.suspend"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/publisherConnections:batchApprove","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections:batchApprove)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.batchApprove"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/publisherConnections:batchReject","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections:batchReject)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.batchReject"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/creatives","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/userLists","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}:close","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.close"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}:open","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::open)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.open"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions/{biddingFunctionsId}:activate","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.activate"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions/{biddingFunctionsId}:archive","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.archive"},{"hostname":"realtimebidding.googleapis.com","http_method":"PUT","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.update"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/firewallpolicies/{firewallpoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.delete"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.delete"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/firewallpolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/firewallpolicies/{firewallpoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.get"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.get"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys/{keysId}/metrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.getMetrics"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys/{keysId}:retrieveLegacySecretKey","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveLegacySecretKey)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.retrieveLegacySecretKey"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/relatedaccountgroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/relatedaccountgroups)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.relatedaccountgroups.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/relatedaccountgroups/{relatedaccountgroupsId}/memberships","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/relatedaccountgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.relatedaccountgroups.memberships.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/firewallpolicies/{firewallpoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.patch"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.patch"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/assessments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assessments)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.assessments.create"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/assessments/{assessmentsId}:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assessments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::annotate)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.assessments.annotate"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/firewallpolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.create"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.create"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/keys/{keysId}:migrate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::migrate)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.migrate"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/relatedaccountgroupmemberships:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/relatedaccountgroupmemberships:search)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.relatedaccountgroupmemberships.search"},{"hostname":"recommendationengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems/{catalogItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.delete"},{"hostname":"recommendationengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/predictionApiKeyRegistrations/{predictionApiKeyRegistrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/predictionApiKeyRegistrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.predictionApiKeyRegistrations.delete"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems/{catalogItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.get"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.operations.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.operations.get"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/predictionApiKeyRegistrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/predictionApiKeyRegistrations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.predictionApiKeyRegistrations.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:collect","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.collect"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.operations.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.operations.get"},{"hostname":"recommendationengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.patch"},{"hostname":"recommendationengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems/{catalogItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.patch"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.create"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems:import)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.import"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/placements/{placementsId}:predict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.placements.predict"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/predictionApiKeyRegistrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/predictionApiKeyRegistrations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.predictionApiKeyRegistrations.create"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.import"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:purge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.purge"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:rejoin","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.rejoin"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:write","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.write"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markSucceeded"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.delete"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.redis","resource_name":"redis.projects.locations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/authString","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authString)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.getAuthString"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.redis","resource_name":"redis.projects.locations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/authString","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authString)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.getAuthString"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.get"},{"hostname":"redis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.patch"},{"hostname":"redis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.patch"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.create"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.export"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:failover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failover)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.failover"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.import"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.rescheduleMaintenance"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.upgrade"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.cancel"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.create"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.export"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:failover","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failover)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.failover"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.import"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.rescheduleMaintenance"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.upgrade"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.cancel"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.delete"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.media.download"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.list"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.operations.get"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/actionResults/{hash}/{sizeBytes}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actionResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.actionResults.get"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/blobs/{hash}/{sizeBytes}:getTree","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getTree)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.getTree"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/capabilities","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capabilities)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.getCapabilities"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.media.upload"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.cancel"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/operations/{operationsId}:waitExecution","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::waitExecution)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.waitExecution"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/actions:execute","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions:execute)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.actions.execute"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/blobs:batchRead","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs:batchRead)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.batchRead"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/blobs:batchUpdate","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs:batchUpdate)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.batchUpdate"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/blobs:findMissing","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs:findMissing)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.findMissing"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"PUT","path_template":"/v2/{v2Id}/actionResults/{hash}/{sizeBytes}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actionResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.actionResults.update"},{"hostname":"reseller.googleapis.com","http_method":"DELETE","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.subscriptions.delete"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/customers/{customerId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.customers.get"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.subscriptions.get"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/resellernotify/getwatchdetails","path_regex":"^(?:/apps/reseller/v1/resellernotify/getwatchdetails)$","service_name":"google.reseller","resource_name":"reseller.resellernotify.getwatchdetails"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/subscriptions","path_regex":"^(?:/apps/reseller/v1/subscriptions)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.list"},{"hostname":"reseller.googleapis.com","http_method":"PATCH","path_template":"/apps/reseller/v1/customers/{customerId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.customers.patch"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers","path_regex":"^(?:/apps/reseller/v1/customers)$","service_name":"google.reseller","resource_name":"reseller.customers.insert"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.insert"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/activate","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activate)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.activate"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/changePlan","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changePlan)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.changePlan"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/changeRenewalSettings","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeRenewalSettings)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.changeRenewalSettings"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/changeSeats","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeSeats)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.changeSeats"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/startPaidService","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startPaidService)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.startPaidService"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/suspend","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.suspend"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/resellernotify/register","path_regex":"^(?:/apps/reseller/v1/resellernotify/register)$","service_name":"google.reseller","resource_name":"reseller.resellernotify.register"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/resellernotify/unregister","path_regex":"^(?:/apps/reseller/v1/resellernotify/unregister)$","service_name":"google.reseller","resource_name":"reseller.resellernotify.unregister"},{"hostname":"reseller.googleapis.com","http_method":"PUT","path_template":"/apps/reseller/v1/customers/{customerId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.customers.update"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/settings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.resourcesettings","resource_name":"resourcesettings.folders.settings.list"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/settings/{settingsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.folders.settings.get"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/settings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.resourcesettings","resource_name":"resourcesettings.organizations.settings.list"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/settings/{settingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.organizations.settings.get"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.resourcesettings","resource_name":"resourcesettings.projects.settings.list"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/settings/{settingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.projects.settings.get"},{"hostname":"resourcesettings.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/settings/{settingsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.folders.settings.patch"},{"hostname":"resourcesettings.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/settings/{settingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.organizations.settings.patch"},{"hostname":"resourcesettings.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/settings/{settingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.projects.settings.patch"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/merchantCenterAccountLinks/{merchantCenterAccountLinksId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantCenterAccountLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.merchantCenterAccountLinks.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.delete"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:collect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.collect"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:completeQuery","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completeQuery"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:getDefaultBranch","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/places/{placesId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/places/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.places.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/merchantCenterAccountLinks","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantCenterAccountLinks)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.merchantCenterAccountLinks.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:collect","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.collect"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:completeQuery","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completeQuery"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:getDefaultBranch","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:collect","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.collect"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:completeQuery","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completeQuery"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:getDefaultBranch","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.operations.get"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.patch"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:addCatalogAttribute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:addCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.addCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:removeCatalogAttribute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:removeCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.removeCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:replaceCatalogAttribute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:replaceCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.replaceCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addFulfillmentPlaces","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addLocalInventories","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeFulfillmentPlaces","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeLocalInventories","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:setInventory","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setInventory)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.setInventory"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionData:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionData:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completionData.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:pause","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.pause"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:resume","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.resume"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:tune","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.tune"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:predict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:addControl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.addControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:predict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:removeControl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.removeControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:purge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:rejoin","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.rejoin"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:write","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.write"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:setDefaultBranch","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.setDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:addCatalogAttribute","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:addCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.addCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:batchRemoveCatalogAttributes","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:batchRemoveCatalogAttributes)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.batchRemoveCatalogAttributes"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:removeCatalogAttribute","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:removeCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.removeCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:replaceCatalogAttribute","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:replaceCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.replaceCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addFulfillmentPlaces","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addLocalInventories","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeFulfillmentPlaces","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeLocalInventories","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:setInventory","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setInventory)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.setInventory"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:import","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:purge","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionData:import","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionData:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completionData.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/merchantCenterAccountLinks","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantCenterAccountLinks)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.merchantCenterAccountLinks.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:pause","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.pause"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:resume","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.resume"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:tune","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.tune"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:predict","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:search","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:addControl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.addControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:predict","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:removeControl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.removeControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:import","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:purge","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:rejoin","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.rejoin"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:write","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.write"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:setDefaultBranch","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.setDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:addCatalogAttribute","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:addCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.addCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:batchRemoveCatalogAttributes","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:batchRemoveCatalogAttributes)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.batchRemoveCatalogAttributes"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:removeCatalogAttribute","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:removeCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.removeCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:replaceCatalogAttribute","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:replaceCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.replaceCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addFulfillmentPlaces","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addLocalInventories","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeFulfillmentPlaces","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeLocalInventories","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:setInventory","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setInventory)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.setInventory"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:import","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionData:import","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionData:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completionData.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:pause","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.pause"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:resume","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.resume"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:tune","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.tune"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:predict","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:search","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:addControl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.addControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:predict","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:removeControl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.removeControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:import","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:purge","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:rejoin","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.rejoin"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:write","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.write"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:setDefaultBranch","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.setDefaultBranch"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions/{executionsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.executions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/revisions/{revisionsId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.revisions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.services.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.revisions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.operations.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/revisions/{revisionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.revisions.delete"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/apiextensions.k8s.io/v1beta1/customresourcedefinitions","path_regex":"^(?:/apis/apiextensions\\.k8s\\.io/v1beta1/customresourcedefinitions)$","service_name":"google.run","resource_name":"run.customresourcedefinitions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/apiextensions.k8s.io/v1beta1/namespaces/{namespacesId}/customresourcedefinitions/{customresourcedefinitionsId}","path_regex":"^(?:/apis/apiextensions\\.k8s\\.io/v1beta1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customresourcedefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.customresourcedefinitions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/authorizeddomains","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizeddomains)$","service_name":"google.run","resource_name":"run.namespaces.authorizeddomains.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.run","resource_name":"run.namespaces.executions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions/{executionsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.executions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/tasks","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.run","resource_name":"run.namespaces.tasks.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/tasks/{tasksId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.tasks.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/configurations","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.run","resource_name":"run.namespaces.configurations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/configurations/{configurationsId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.configurations.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/revisions","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.run","resource_name":"run.namespaces.revisions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/revisions/{revisionsId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.revisions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/routes","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.run","resource_name":"run.namespaces.routes.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/routes/{routesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.routes.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.namespaces.services.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.services.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/authorizeddomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizeddomains)$","service_name":"google.run","resource_name":"run.projects.authorizeddomains.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.run","resource_name":"run.projects.locations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizeddomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizeddomains)$","service_name":"google.run","resource_name":"run.projects.locations.authorizeddomains.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/configurations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.run","resource_name":"run.projects.locations.configurations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/configurations/{configurationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.configurations.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/revisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.run","resource_name":"run.projects.locations.revisions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.revisions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/routes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.run","resource_name":"run.projects.locations.routes.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/routes/{routesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.routes.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customresourcedefinitions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customresourcedefinitions)$","service_name":"google.run","resource_name":"run.projects.locations.customresourcedefinitions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customresourcedefinitions/{customresourcedefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customresourcedefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.customresourcedefinitions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}/tasks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.tasks.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}/tasks/{tasksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.tasks.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.run","resource_name":"run.projects.locations.operations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.operations.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/revisions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.run","resource_name":"run.projects.locations.services.revisions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/revisions/{revisionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.revisions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.patch"},{"hostname":"run.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.patch"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions/{executionsId}:cancel","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.run","resource_name":"run.namespaces.executions.cancel"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}:run","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.run","resource_name":"run.namespaces.jobs.run"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.namespaces.services.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.services.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:run","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.run"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.run","resource_name":"run.projects.locations.operations.wait"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.services.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"PUT","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.replaceJob"},{"hostname":"run.googleapis.com","http_method":"PUT","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.services.replaceService"},{"hostname":"run.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.replaceService"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.operations.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters/{waitersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.operations.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.operations.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters/{waitersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.getIamPolicy"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.operations.cancel"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.create"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/operations/{operationsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.operations.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.create"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}:watch","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::watch)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.watch"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.create"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters/{waitersId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.setIamPolicy"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.update"},{"hostname":"runtimeconfig.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.update"},{"hostname":"safebrowsing.googleapis.com","http_method":"GET","path_template":"/v4/encodedFullHashes/{encodedRequest}","path_regex":"^(?:/v4/encodedFullHashes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.safebrowsing","resource_name":"safebrowsing.encodedFullHashes.get"},{"hostname":"safebrowsing.googleapis.com","http_method":"GET","path_template":"/v4/encodedUpdates/{encodedRequest}","path_regex":"^(?:/v4/encodedUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.safebrowsing","resource_name":"safebrowsing.encodedUpdates.get"},{"hostname":"safebrowsing.googleapis.com","http_method":"GET","path_template":"/v4/threatLists","path_regex":"^(?:/v4/threatLists)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatLists.list"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/fullHashes:find","path_regex":"^(?:/v4/fullHashes:find)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.fullHashes.find"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/threatHits","path_regex":"^(?:/v4/threatHits)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatHits.create"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/threatListUpdates:fetch","path_regex":"^(?:/v4/threatListUpdates:fetch)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatListUpdates.fetch"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/threatMatches:find","path_regex":"^(?:/v4/threatMatches:find)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatMatches.find"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.delete"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers","path_regex":"^(?:/v1alpha1/customers)$","service_name":"google.sasportal","resource_name":"sasportal.customers.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.updateSigned"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.updateSigned"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.updateSigned"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.patch"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.signDevice"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.deployments.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:provisionDeployment","path_regex":"^(?:/v1alpha1/customers:provisionDeployment)$","service_name":"google.sasportal","resource_name":"sasportal.customers.provisionDeployment"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.signDevice"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:generateSecret","path_regex":"^(?:/v1alpha1/installer:generateSecret)$","service_name":"google.sasportal","resource_name":"sasportal.installer.generateSecret"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:validate","path_regex":"^(?:/v1alpha1/installer:validate)$","service_name":"google.sasportal","resource_name":"sasportal.installer.validate"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.signDevice"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.deployments.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:get","path_regex":"^(?:/v1alpha1/policies:get)$","service_name":"google.sasportal","resource_name":"sasportal.policies.get"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:set","path_regex":"^(?:/v1alpha1/policies:set)$","service_name":"google.sasportal","resource_name":"sasportal.policies.set"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:test","path_regex":"^(?:/v1alpha1/policies:test)$","service_name":"google.sasportal","resource_name":"sasportal.policies.test"},{"hostname":"script.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{scriptId}/deployments/{deploymentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.deployments.delete"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/processes","path_regex":"^(?:/v1/processes)$","service_name":"google.script","resource_name":"script.processes.list"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/processes:listScriptProcesses","path_regex":"^(?:/v1/processes:listScriptProcesses)$","service_name":"google.script","resource_name":"script.processes.listScriptProcesses"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.get"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.script","resource_name":"script.projects.getContent"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.script","resource_name":"script.projects.deployments.list"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/deployments/{deploymentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.deployments.get"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/metrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.script","resource_name":"script.projects.getMetrics"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.script","resource_name":"script.projects.versions.list"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/versions/{versionNumber}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.versions.get"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.script","resource_name":"script.projects.create"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/projects/{scriptId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.script","resource_name":"script.projects.deployments.create"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/projects/{scriptId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.script","resource_name":"script.projects.versions.create"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/scripts/{scriptId}:run","path_regex":"^(?:/v1/scripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.script","resource_name":"script.scripts.run"},{"hostname":"script.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{scriptId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.script","resource_name":"script.projects.updateContent"},{"hostname":"script.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{scriptId}/deployments/{deploymentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.deployments.update"},{"hostname":"searchads360.googleapis.com","http_method":"GET","path_template":"/v0/customers/{customersId}/customColumns","path_regex":"^(?:/v0/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customColumns)$","service_name":"google.searchads360","resource_name":"searchads360.customers.customColumns.list"},{"hostname":"searchads360.googleapis.com","http_method":"GET","path_template":"/v0/customers/{customersId}/customColumns/{customColumnsId}","path_regex":"^(?:/v0/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customColumns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchads360","resource_name":"searchads360.customers.customColumns.get"},{"hostname":"searchads360.googleapis.com","http_method":"GET","path_template":"/v0/searchAds360Fields/{searchAds360FieldsId}","path_regex":"^(?:/v0/searchAds360Fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchads360","resource_name":"searchads360.searchAds360Fields.get"},{"hostname":"searchads360.googleapis.com","http_method":"POST","path_template":"/v0/customers/{customersId}/searchAds360:search","path_regex":"^(?:/v0/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360:search)$","service_name":"google.searchads360","resource_name":"searchads360.customers.searchAds360.search"},{"hostname":"searchads360.googleapis.com","http_method":"POST","path_template":"/v0/customers/{customersId}/searchAds360:searchStream","path_regex":"^(?:/v0/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360:searchStream)$","service_name":"google.searchads360","resource_name":"searchads360.customers.searchAds360.searchStream"},{"hostname":"searchads360.googleapis.com","http_method":"POST","path_template":"/v0/searchAds360Fields:search","path_regex":"^(?:/v0/searchAds360Fields:search)$","service_name":"google.searchads360","resource_name":"searchads360.searchAds360Fields.search"},{"hostname":"searchconsole.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sites.delete"},{"hostname":"searchconsole.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.delete"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites","path_regex":"^(?:/webmasters/v3/sites)$","service_name":"google.searchconsole","resource_name":"webmasters.sites.list"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sites.get"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps)$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.list"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.get"},{"hostname":"searchconsole.googleapis.com","http_method":"POST","path_template":"/v1/urlInspection/index:inspect","path_regex":"^(?:/v1/urlInspection/index:inspect)$","service_name":"google.searchconsole","resource_name":"searchconsole.urlInspection.index.inspect"},{"hostname":"searchconsole.googleapis.com","http_method":"POST","path_template":"/v1/urlTestingTools/mobileFriendlyTest:run","path_regex":"^(?:/v1/urlTestingTools/mobileFriendlyTest:run)$","service_name":"google.searchconsole","resource_name":"searchconsole.urlTestingTools.mobileFriendlyTest.run"},{"hostname":"searchconsole.googleapis.com","http_method":"POST","path_template":"/webmasters/v3/sites/{siteUrl}/searchAnalytics/query","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAnalytics/query)$","service_name":"google.searchconsole","resource_name":"webmasters.searchanalytics.query"},{"hostname":"searchconsole.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sites.add"},{"hostname":"searchconsole.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.submit"},{"hostname":"secretmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.delete"},{"hostname":"secretmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.delete"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:access","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::access)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.access"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.getIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:access","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::access)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.access"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.getIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.patch"},{"hostname":"secretmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.patch"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.create"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:destroy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.destroy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.disable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.enable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:addVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addVersion)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.addVersion"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.setIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.testIamPermissions"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.create"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:destroy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.destroy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:disable","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.disable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:enable","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.enable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:addVersion","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addVersion)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.addVersion"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.setIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.testIamPermissions"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/assets","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/bigQueryExports","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/muteConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/notificationConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules:listDescendant","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/effectiveCustomModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/sources","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/assets","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/bigQueryExports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/muteConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules:listDescendant","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/effectiveCustomModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/assets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/bigQueryExports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/muteConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notificationConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules:listDescendant","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/effectiveCustomModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/assets","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/eventThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/onboardingState","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/onboardingState)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getOnboardingState"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/rapidVulnerabilityDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.rapidVulnerabilityDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/securityCenterSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityCenterSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getSecurityCenterSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/securityHealthAnalyticsSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/virtualMachineThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.virtualMachineThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/webSecurityScannerSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.webSecurityScannerSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/eventThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/onboardingState","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/onboardingState)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getOnboardingState"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/rapidVulnerabilityDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.rapidVulnerabilityDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/securityCenterSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityCenterSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getSecurityCenterSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/securityHealthAnalyticsSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/subscription","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscription)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getSubscription"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/virtualMachineThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.virtualMachineThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/webSecurityScannerSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.webSecurityScannerSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/eventThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.clusters.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.clusters.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/onboardingState","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/onboardingState)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getOnboardingState"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/rapidVulnerabilityDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.rapidVulnerabilityDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/securityCenterSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityCenterSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getSecurityCenterSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/securityHealthAnalyticsSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/virtualMachineThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.virtualMachineThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/webSecurityScannerSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.webSecurityScannerSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/assets","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}/externalSystems/{externalSystemsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.externalSystems.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/externalSystems/{externalSystemsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.externalSystems.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}/externalSystems/{externalSystemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.externalSystems.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.clusters.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/assets:group","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/bigQueryExports","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/findings:bulkMute","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:bulkMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.findings.bulkMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/muteConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/notificationConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}:setMute","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.setMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/assets:group","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/assets:runDiscovery","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:runDiscovery)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.runDiscovery"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/bigQueryExports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/findings:bulkMute","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:bulkMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.findings.bulkMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/muteConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setMute","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.getIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.setIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.testIamPermissions"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/assets:group","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/bigQueryExports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/findings:bulkMute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:bulkMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.findings.bulkMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/muteConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notificationConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}:setMute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.setMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/assets:group","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/assets:runDiscovery","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:runDiscovery)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.runDiscovery"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}:getIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.getIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}:setIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.setIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}:testIamPermissions","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.testIamPermissions"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/assets:group","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/assets:runDiscovery","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:runDiscovery)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.runDiscovery"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}:getIamPolicy","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.getIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}:setIamPolicy","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.setIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}:testIamPermissions","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{instanceId}/service_bindings/{bindingId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}:getIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.getIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/service_bindings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.service_bindings.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/service_instances","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_instances)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.service_instances.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/catalog","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/catalog)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.catalog.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/last_operation","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}/last_operation","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/{v1alpha1Id}:getIamPolicy","path_regex":"^(?:/v1alpha1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.getIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/bindings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.bindings.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/bindings/{bindingsId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.bindings.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/catalog","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/catalog)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.catalog.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}:getIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.getIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.patch"},{"hostname":"servicebroker.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.patch"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:setIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.setIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:testIamPermissions","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicebroker","resource_name":"servicebroker.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1alpha1/{v1alpha1Id}:setIamPolicy","path_regex":"^(?:/v1alpha1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.setIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1alpha1/{v1alpha1Id}:testIamPermissions","path_regex":"^(?:/v1alpha1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicebroker","resource_name":"servicebroker.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/brokers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.create"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:setIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.setIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:testIamPermissions","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicebroker","resource_name":"servicebroker.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.create"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.create"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.create"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.create"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.delete"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.delete"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides/{producerOverridesId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.delete"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}:search","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.search"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides/{producerOverridesId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.patch"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.cancel"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.create"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:addProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.addProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:applyProjectConfig","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyProjectConfig)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.applyProjectConfig"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:attachProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.attachProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:deleteProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.deleteProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:removeProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.removeProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:undeleteProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeleteProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.undeleteProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.create"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics:importProducerOverrides","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics:importProducerOverrides)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.importProducerOverrides"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:allocateQuota","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::allocateQuota)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.allocateQuota"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:check","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::check)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.check"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:report","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::report)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.report"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v2/services/{serviceName}:check","path_regex":"^(?:/v2/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::check)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.check"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v2/services/{serviceName}:report","path_regex":"^(?:/v2/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::report)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.report"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.resolve"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/serviceWorkloads/{serviceWorkloadsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceWorkloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.serviceWorkloads.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/serviceWorkloads/{serviceWorkloadsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceWorkloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.serviceWorkloads.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/serviceWorkloads/{serviceWorkloadsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceWorkloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.serviceWorkloads.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:resolve","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.resolve"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/workloads/{workloadsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.workloads.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/workloads/{workloadsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.workloads.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/workloads/{workloadsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.workloads.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrationPolicies/{registrationPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.registrationPolicies.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrationPolicies/{registrationPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.registrationPolicies.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrationPolicies/{registrationPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.registrationPolicies.testIamPermissions"},{"hostname":"servicemanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/services/{serviceName}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.delete"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.operations.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.operations.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services","path_regex":"^(?:/v1/services)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/config","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.getConfig"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/configs","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/configs/{configId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/rollouts","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.rollouts.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/rollouts/{rolloutId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.rollouts.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services","path_regex":"^(?:/v1/services)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.create"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}/configs","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.create"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}/configs:submit","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs:submit)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.submit"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}/rollouts","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.rollouts.create"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:undelete","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.undelete"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/consumers/{consumersId}:getIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.consumers.getIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/consumers/{consumersId}:setIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.consumers.setIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/consumers/{consumersId}:testIamPermissions","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.consumers.testIamPermissions"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.getIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.setIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.testIamPermissions"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services:generateConfigReport","path_regex":"^(?:/v1/services:generateConfigReport)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.generateConfigReport"},{"hostname":"servicenetworking.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.delete"},{"hostname":"servicenetworking.googleapis.com","http_method":"DELETE","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/peeredDnsDomains/{peeredDnsDomainsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeredDnsDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.peeredDnsDomains.delete"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/connections","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/peeredDnsDomains","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeredDnsDomains)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.peeredDnsDomains.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1beta/operations/{operationsId}","path_regex":"^(?:/v1beta/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1beta/services/{servicesId}/connections","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}/connections/{connectionsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.patch"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}:updateConsumerConfig","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateConsumerConfig)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.updateConsumerConfig"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}:disableVpcServiceControls","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableVpcServiceControls)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.disableVpcServiceControls"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}:enableVpcServiceControls","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableVpcServiceControls)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.enableVpcServiceControls"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1beta/services/{servicesId}/connections","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.updateConnections"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.cancel"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/connections","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.create"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/connections/{connectionsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.deleteConnection"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsRecordSets:add","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:add)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.add"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsRecordSets:remove","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:remove)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.remove"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsRecordSets:update","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:update)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.update"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsZones:add","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsZones:add)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsZones.add"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsZones:remove","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsZones:remove)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsZones.remove"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/peeredDnsDomains","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeredDnsDomains)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.peeredDnsDomains.create"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/roles:add","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles:add)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.roles.add"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}:addSubnetwork","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addSubnetwork)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.addSubnetwork"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:searchRange","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchRange)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.searchRange"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:validate","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.validate"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1beta/services/{servicesId}/connections","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.create"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1beta/services/{servicesId}/{servicesId1}/{servicesId2}:addSubnetwork","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addSubnetwork)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.addSubnetwork"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1beta/services/{servicesId}:searchRange","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchRange)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.searchRange"},{"hostname":"serviceusage.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.delete"},{"hostname":"serviceusage.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides/{adminOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.delete"},{"hostname":"serviceusage.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides/{consumerOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.delete"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/services","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/services/{servicesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/services:batchGet","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchGet)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.batchGet"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.list"},{"hostname":"serviceusage.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides/{adminOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.patch"},{"hostname":"serviceusage.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides/{consumerOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.patch"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.cancel"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/services/{servicesId}:disable","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.disable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/services/{servicesId}:enable","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.enable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/services:batchEnable","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchEnable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.batchEnable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.create"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.create"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics:importAdminOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics:importAdminOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.importAdminOverrides"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics:importConsumerOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics:importConsumerOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.importConsumerOverrides"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}:disable","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.disable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}:enable","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.enable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}:generateServiceIdentity","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateServiceIdentity)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.generateServiceIdentity"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services:batchEnable","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchEnable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.batchEnable"},{"hostname":"serviceuser.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.serviceuser","resource_name":"serviceuser.projects.services.list"},{"hostname":"serviceuser.googleapis.com","http_method":"GET","path_template":"/v1/services:search","path_regex":"^(?:/v1/services:search)$","service_name":"google.serviceuser","resource_name":"serviceuser.services.search"},{"hostname":"serviceuser.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services/{servicesId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.serviceuser","resource_name":"serviceuser.projects.services.disable"},{"hostname":"serviceuser.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services/{servicesId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.serviceuser","resource_name":"serviceuser.projects.services.enable"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.get"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}/developerMetadata/{metadataId}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developerMetadata/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.developerMetadata.get"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.get"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchGet","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchGet)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchGet"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets","path_regex":"^(?:/v4/spreadsheets)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.create"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/developerMetadata:search","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developerMetadata:search)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.developerMetadata.search"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/sheets/{sheetId}:copyTo","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::copyTo)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.sheets.copyTo"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}:append","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::append)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.append"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}:clear","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clear)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.clear"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchClear","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchClear)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchClear"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchClearByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchClearByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchClearByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchGetByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchGetByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchGetByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchUpdate","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchUpdate)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchUpdate"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchUpdateByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchUpdateByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchUpdateByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}:batchUpdate","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.batchUpdate"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}:getByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.getByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"PUT","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/accounts/{accountId}/labels/{labelId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.labels.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/accounts/{accountId}/returncarrier/{carrierAccountId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.returncarrier.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/collections/{collectionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.collections.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.conversionsources.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/productdeliverytime/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productdeliverytime/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productdeliverytime.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/regions/{regionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.regions.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/repricingrules/{ruleId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingrules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.repricingrules.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/returnaddress/{returnAddressId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnaddress.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/returnpolicy/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicy.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/returnpolicyonline/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicyonline.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/accounts/authinfo","path_regex":"^(?:/content/v2\\.1/accounts/authinfo)$","service_name":"google.content","resource_name":"content.accounts.authinfo"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/accounts/{accountId}/labels","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.content","resource_name":"content.accounts.labels.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/accounts/{accountId}/returncarrier","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier)$","service_name":"google.content","resource_name":"content.accounts.returncarrier.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/liasettings/posdataproviders","path_regex":"^(?:/content/v2\\.1/liasettings/posdataproviders)$","service_name":"google.content","resource_name":"content.liasettings.listposdataproviders"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{cssGroupId}/csses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csses)$","service_name":"google.content","resource_name":"content.csses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{cssGroupId}/csses/{cssDomainId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.csses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounts","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/listlinks","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listlinks)$","service_name":"google.content","resource_name":"content.accounts.listlinks"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accountstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses)$","service_name":"google.content","resource_name":"content.accountstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accountstatuses/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accountstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounttax","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax)$","service_name":"google.content","resource_name":"content.accounttax.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.buyongoogleprograms.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collections","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections)$","service_name":"google.content","resource_name":"content.collections.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collections/{collectionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.collections.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collectionstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionstatuses)$","service_name":"google.content","resource_name":"content.collectionstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collectionstatuses/{collectionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.collectionstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/conversionsources","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources)$","service_name":"google.content","resource_name":"content.conversionsources.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.conversionsources.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeeds","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeedstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses)$","service_name":"google.content","resource_name":"content.datafeedstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeedstatuses/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeedstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/freelistingsprogram","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/freelistingsprogram)$","service_name":"google.content","resource_name":"content.freelistingsprogram.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/liasettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings)$","service_name":"google.content","resource_name":"content.liasettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/accessiblegmbaccounts","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessiblegmbaccounts)$","service_name":"google.content","resource_name":"content.liasettings.getaccessiblegmbaccounts"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreports/disbursements","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements)$","service_name":"google.content","resource_name":"content.orderreports.listdisbursements"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreports/disbursements/{disbursementId}/transactions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transactions)$","service_name":"google.content","resource_name":"content.orderreports.listtransactions"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreturns","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns)$","service_name":"google.content","resource_name":"content.orderreturns.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orderreturns.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orders","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.content","resource_name":"content.orders.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orders/{orderId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/ordersbymerchantid/{merchantOrderId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordersbymerchantid/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.getbymerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/productdeliverytime/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productdeliverytime/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productdeliverytime.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/products","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/productstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses)$","service_name":"google.content","resource_name":"content.productstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/productstatuses/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/productstatuses/{productId}/repricingreports","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingreports)$","service_name":"google.content","resource_name":"content.productstatuses.repricingreports.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/promotions/{id}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.promotions.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/pubsubnotificationsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pubsubnotificationsettings)$","service_name":"google.content","resource_name":"content.pubsubnotificationsettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/quotas","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/quotas)$","service_name":"google.content","resource_name":"content.quotas.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/recommendations/generate","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/generate)$","service_name":"google.content","resource_name":"content.recommendations.generate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/regions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.content","resource_name":"content.regions.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/regions/{regionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.regions.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/repricingrules","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingrules)$","service_name":"google.content","resource_name":"content.repricingrules.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/repricingrules/{ruleId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingrules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.repricingrules.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/repricingrules/{ruleId}/repricingreports","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingrules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingreports)$","service_name":"google.content","resource_name":"content.repricingrules.repricingreports.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnaddress","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress)$","service_name":"google.content","resource_name":"content.returnaddress.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnaddress/{returnAddressId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnaddress.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicy","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy)$","service_name":"google.content","resource_name":"content.returnpolicy.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicy/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicy.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicyonline","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline)$","service_name":"google.content","resource_name":"content.returnpolicyonline.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicyonline/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicyonline.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/settlementreports","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settlementreports)$","service_name":"google.content","resource_name":"content.settlementreports.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/settlementreports/{settlementId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settlementreports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.settlementreports.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/settlementreports/{settlementId}/transactions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settlementreports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transactions)$","service_name":"google.content","resource_name":"content.settlementtransactions.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/shippingsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings)$","service_name":"google.content","resource_name":"content.shippingsettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/shoppingadsprogram","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shoppingadsprogram)$","service_name":"google.content","resource_name":"content.shoppingadsprogram.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/supportedCarriers","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedCarriers)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedcarriers"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/supportedHolidays","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedHolidays)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedholidays"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/supportedPickupServices","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedPickupServices)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedpickupservices"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/testordertemplates/{templateName}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testordertemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.gettestordertemplate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/accounts/authinfo","path_regex":"^(?:/content/v2/accounts/authinfo)$","service_name":"google.content","resource_name":"content.accounts.authinfo"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/liasettings/posdataproviders","path_regex":"^(?:/content/v2/liasettings/posdataproviders)$","service_name":"google.content","resource_name":"content.liasettings.listposdataproviders"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounts","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accountstatuses","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses)$","service_name":"google.content","resource_name":"content.accountstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accountstatuses/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accountstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounttax","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax)$","service_name":"google.content","resource_name":"content.accounttax.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeeds","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeedstatuses","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses)$","service_name":"google.content","resource_name":"content.datafeedstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeedstatuses/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeedstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/liasettings","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings)$","service_name":"google.content","resource_name":"content.liasettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/accessiblegmbaccounts","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessiblegmbaccounts)$","service_name":"google.content","resource_name":"content.liasettings.getaccessiblegmbaccounts"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreports/disbursements","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements)$","service_name":"google.content","resource_name":"content.orderreports.listdisbursements"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreports/disbursements/{disbursementId}/transactions","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transactions)$","service_name":"google.content","resource_name":"content.orderreports.listtransactions"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreturns","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns)$","service_name":"google.content","resource_name":"content.orderreturns.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreturns/{returnId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orderreturns.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orders","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.content","resource_name":"content.orders.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orders/{orderId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/ordersbymerchantid/{merchantOrderId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordersbymerchantid/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.getbymerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/products","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/productstatuses","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses)$","service_name":"google.content","resource_name":"content.productstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/productstatuses/{productId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/shippingsettings","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings)$","service_name":"google.content","resource_name":"content.shippingsettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/supportedCarriers","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedCarriers)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedcarriers"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/supportedHolidays","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedHolidays)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedholidays"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/supportedPickupServices","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedPickupServices)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedpickupservices"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/testordertemplates/{templateName}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testordertemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.gettestordertemplate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/accounts/{accountId}/labels/{labelId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.labels.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/accounts/{accountId}/returncarrier/{carrierAccountId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.returncarrier.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.buyongoogleprograms.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.conversionsources.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/regions/{regionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.regions.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/repricingrules/{ruleId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingrules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.repricingrules.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/returnpolicyonline/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicyonline.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/batch","path_regex":"^(?:/content/v2\\.1/accounts/batch)$","service_name":"google.content","resource_name":"content.accounts.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/{accountId}/credentials","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credentials)$","service_name":"google.content","resource_name":"content.accounts.credentials.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/{accountId}/labels","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.content","resource_name":"content.accounts.labels.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/{accountId}/returncarrier","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier)$","service_name":"google.content","resource_name":"content.accounts.returncarrier.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accountstatuses/batch","path_regex":"^(?:/content/v2\\.1/accountstatuses/batch)$","service_name":"google.content","resource_name":"content.accountstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounttax/batch","path_regex":"^(?:/content/v2\\.1/accounttax/batch)$","service_name":"google.content","resource_name":"content.accounttax.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/datafeeds/batch","path_regex":"^(?:/content/v2\\.1/datafeeds/batch)$","service_name":"google.content","resource_name":"content.datafeeds.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/datafeedstatuses/batch","path_regex":"^(?:/content/v2\\.1/datafeedstatuses/batch)$","service_name":"google.content","resource_name":"content.datafeedstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/liasettings/batch","path_regex":"^(?:/content/v2\\.1/liasettings/batch)$","service_name":"google.content","resource_name":"content.liasettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/localinventory/batch","path_regex":"^(?:/content/v2\\.1/localinventory/batch)$","service_name":"google.content","resource_name":"content.localinventory.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/pos/batch","path_regex":"^(?:/content/v2\\.1/pos/batch)$","service_name":"google.content","resource_name":"content.pos.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/products/batch","path_regex":"^(?:/content/v2\\.1/products/batch)$","service_name":"google.content","resource_name":"content.products.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/productstatuses/batch","path_regex":"^(?:/content/v2\\.1/productstatuses/batch)$","service_name":"google.content","resource_name":"content.productstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/regionalinventory/batch","path_regex":"^(?:/content/v2\\.1/regionalinventory/batch)$","service_name":"google.content","resource_name":"content.regionalinventory.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/returnaddress/batch","path_regex":"^(?:/content/v2\\.1/returnaddress/batch)$","service_name":"google.content","resource_name":"content.returnaddress.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/returnpolicy/batch","path_regex":"^(?:/content/v2\\.1/returnpolicy/batch)$","service_name":"google.content","resource_name":"content.returnpolicy.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/shippingsettings/batch","path_regex":"^(?:/content/v2\\.1/shippingsettings/batch)$","service_name":"google.content","resource_name":"content.shippingsettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{cssGroupId}/csses/{cssDomainId}/updatelabels","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatelabels)$","service_name":"google.content","resource_name":"content.csses.updatelabels"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/claimwebsite","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/claimwebsite)$","service_name":"google.content","resource_name":"content.accounts.claimwebsite"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/link","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/link)$","service_name":"google.content","resource_name":"content.accounts.link"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/requestphoneverification","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestphoneverification)$","service_name":"google.content","resource_name":"content.accounts.requestphoneverification"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/updatelabels","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatelabels)$","service_name":"google.content","resource_name":"content.accounts.updatelabels"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/verifyphonenumber","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyphonenumber)$","service_name":"google.content","resource_name":"content.accounts.verifyphonenumber"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/activate","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activate)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.activate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/onboard","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/onboard)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.onboard"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/pause","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pause)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.pause"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/requestreview","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestreview)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.requestreview"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/collections","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections)$","service_name":"google.content","resource_name":"content.collections.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/conversionsources","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources)$","service_name":"google.content","resource_name":"content.conversionsources.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}:undelete","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.content","resource_name":"content.conversionsources.undelete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/datafeeds","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}/fetchNow","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fetchNow)$","service_name":"google.content","resource_name":"content.datafeeds.fetchnow"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/freelistingsprogram/requestreview","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/freelistingsprogram/requestreview)$","service_name":"google.content","resource_name":"content.freelistingsprogram.requestreview"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/requestgmbaccess","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestgmbaccess)$","service_name":"google.content","resource_name":"content.liasettings.requestgmbaccess"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/requestinventoryverification/{country}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestinventoryverification/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.requestinventoryverification"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/setinventoryverificationcontact","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setinventoryverificationcontact)$","service_name":"google.content","resource_name":"content.liasettings.setinventoryverificationcontact"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/setposdataprovider","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setposdataprovider)$","service_name":"google.content","resource_name":"content.liasettings.setposdataprovider"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderinvoices/{orderId}/createChargeInvoice","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createChargeInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createchargeinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderinvoices/{orderId}/createRefundInvoice","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createRefundInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createrefundinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/createOrderReturn","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/createOrderReturn)$","service_name":"google.content","resource_name":"content.orderreturns.createorderreturn"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}/acknowledge","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orderreturns.acknowledge"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}/labels","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.content","resource_name":"content.orderreturns.labels.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}/process","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/process)$","service_name":"google.content","resource_name":"content.orderreturns.process"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/acknowledge","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orders.acknowledge"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/cancel","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.content","resource_name":"content.orders.cancel"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/cancelLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelLineItem)$","service_name":"google.content","resource_name":"content.orders.cancellineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/captureOrder","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/captureOrder)$","service_name":"google.content","resource_name":"content.orders.captureOrder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/inStoreRefundLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inStoreRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.instorerefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/refunditem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refunditem)$","service_name":"google.content","resource_name":"content.orders.refunditem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/refundorder","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refundorder)$","service_name":"google.content","resource_name":"content.orders.refundorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/rejectReturnLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rejectReturnLineItem)$","service_name":"google.content","resource_name":"content.orders.rejectreturnlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/returnRefundLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.returnrefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/setLineItemMetadata","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLineItemMetadata)$","service_name":"google.content","resource_name":"content.orders.setlineitemmetadata"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/shipLineItems","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shipLineItems)$","service_name":"google.content","resource_name":"content.orders.shiplineitems"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/testreturn","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testreturn)$","service_name":"google.content","resource_name":"content.orders.createtestreturn"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/updateLineItemShippingDetails","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateLineItemShippingDetails)$","service_name":"google.content","resource_name":"content.orders.updatelineitemshippingdetails"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/updateMerchantOrderId","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateMerchantOrderId)$","service_name":"google.content","resource_name":"content.orders.updatemerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/updateShipment","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShipment)$","service_name":"google.content","resource_name":"content.orders.updateshipment"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/ordertrackingsignals","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordertrackingsignals)$","service_name":"google.content","resource_name":"content.ordertrackingsignals.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/inventory","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.content","resource_name":"content.pos.inventory"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/sale","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sale)$","service_name":"google.content","resource_name":"content.pos.sale"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/productdeliverytime","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productdeliverytime)$","service_name":"google.content","resource_name":"content.productdeliverytime.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/products","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/products/{productId}/localinventory","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/localinventory)$","service_name":"google.content","resource_name":"content.localinventory.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/products/{productId}/regionalinventory","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalinventory)$","service_name":"google.content","resource_name":"content.regionalinventory.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/promotions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions)$","service_name":"google.content","resource_name":"content.promotions.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/recommendations/reportInteraction","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/reportInteraction)$","service_name":"google.content","resource_name":"content.recommendations.reportInteraction"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/regions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.content","resource_name":"content.regions.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/reports/search","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/search)$","service_name":"google.content","resource_name":"content.reports.search"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/repricingrules","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repricingrules)$","service_name":"google.content","resource_name":"content.repricingrules.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/returnaddress","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress)$","service_name":"google.content","resource_name":"content.returnaddress.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/returnpolicy","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy)$","service_name":"google.content","resource_name":"content.returnpolicy.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/returnpolicyonline","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline)$","service_name":"google.content","resource_name":"content.returnpolicyonline.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/shoppingadsprogram/requestreview","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shoppingadsprogram/requestreview)$","service_name":"google.content","resource_name":"content.shoppingadsprogram.requestreview"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/testorders","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders)$","service_name":"google.content","resource_name":"content.orders.createtestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/testorders/{orderId}/advance","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advance)$","service_name":"google.content","resource_name":"content.orders.advancetestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/testorders/{orderId}/cancelByCustomer","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelByCustomer)$","service_name":"google.content","resource_name":"content.orders.canceltestorderbycustomer"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/accounts/batch","path_regex":"^(?:/content/v2/accounts/batch)$","service_name":"google.content","resource_name":"content.accounts.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/accountstatuses/batch","path_regex":"^(?:/content/v2/accountstatuses/batch)$","service_name":"google.content","resource_name":"content.accountstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/accounttax/batch","path_regex":"^(?:/content/v2/accounttax/batch)$","service_name":"google.content","resource_name":"content.accounttax.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/datafeeds/batch","path_regex":"^(?:/content/v2/datafeeds/batch)$","service_name":"google.content","resource_name":"content.datafeeds.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/datafeedstatuses/batch","path_regex":"^(?:/content/v2/datafeedstatuses/batch)$","service_name":"google.content","resource_name":"content.datafeedstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/liasettings/batch","path_regex":"^(?:/content/v2/liasettings/batch)$","service_name":"google.content","resource_name":"content.liasettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/orders/batch","path_regex":"^(?:/content/v2/orders/batch)$","service_name":"google.content","resource_name":"content.orders.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/pos/batch","path_regex":"^(?:/content/v2/pos/batch)$","service_name":"google.content","resource_name":"content.pos.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/products/batch","path_regex":"^(?:/content/v2/products/batch)$","service_name":"google.content","resource_name":"content.products.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/productstatuses/batch","path_regex":"^(?:/content/v2/productstatuses/batch)$","service_name":"google.content","resource_name":"content.productstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/shippingsettings/batch","path_regex":"^(?:/content/v2/shippingsettings/batch)$","service_name":"google.content","resource_name":"content.shippingsettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/accounts","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/accounts/{accountId}/claimwebsite","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/claimwebsite)$","service_name":"google.content","resource_name":"content.accounts.claimwebsite"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/accounts/{accountId}/link","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/link)$","service_name":"google.content","resource_name":"content.accounts.link"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/datafeeds","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}/fetchNow","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fetchNow)$","service_name":"google.content","resource_name":"content.datafeeds.fetchnow"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/requestgmbaccess","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestgmbaccess)$","service_name":"google.content","resource_name":"content.liasettings.requestgmbaccess"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/requestinventoryverification/{country}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestinventoryverification/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.requestinventoryverification"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/setinventoryverificationcontact","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setinventoryverificationcontact)$","service_name":"google.content","resource_name":"content.liasettings.setinventoryverificationcontact"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/setposdataprovider","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setposdataprovider)$","service_name":"google.content","resource_name":"content.liasettings.setposdataprovider"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orderinvoices/{orderId}/createChargeInvoice","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createChargeInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createchargeinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orderinvoices/{orderId}/createRefundInvoice","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createRefundInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createrefundinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/acknowledge","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orders.acknowledge"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/cancel","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.content","resource_name":"content.orders.cancel"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/cancelLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelLineItem)$","service_name":"google.content","resource_name":"content.orders.cancellineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/inStoreRefundLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inStoreRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.instorerefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/refund","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refund)$","service_name":"google.content","resource_name":"content.orders.refund"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/rejectReturnLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rejectReturnLineItem)$","service_name":"google.content","resource_name":"content.orders.rejectreturnlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/returnLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnLineItem)$","service_name":"google.content","resource_name":"content.orders.returnlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/returnRefundLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.returnrefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/setLineItemMetadata","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLineItemMetadata)$","service_name":"google.content","resource_name":"content.orders.setlineitemmetadata"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/shipLineItems","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shipLineItems)$","service_name":"google.content","resource_name":"content.orders.shiplineitems"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/testreturn","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testreturn)$","service_name":"google.content","resource_name":"content.orders.createtestreturn"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/updateLineItemShippingDetails","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateLineItemShippingDetails)$","service_name":"google.content","resource_name":"content.orders.updatelineitemshippingdetails"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/updateMerchantOrderId","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateMerchantOrderId)$","service_name":"google.content","resource_name":"content.orders.updatemerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/updateShipment","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShipment)$","service_name":"google.content","resource_name":"content.orders.updateshipment"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/inventory","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.content","resource_name":"content.pos.inventory"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/sale","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sale)$","service_name":"google.content","resource_name":"content.pos.sale"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/products","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/testorders","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders)$","service_name":"google.content","resource_name":"content.orders.createtestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/testorders/{orderId}/advance","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advance)$","service_name":"google.content","resource_name":"content.orders.advancetestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/testorders/{orderId}/cancelByCustomer","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelByCustomer)$","service_name":"google.content","resource_name":"content.orders.canceltestorderbycustomer"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/pubsubnotificationsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pubsubnotificationsettings)$","service_name":"google.content","resource_name":"content.pubsubnotificationsettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.update"},{"hostname":"slides.googleapis.com","http_method":"GET","path_template":"/v1/presentations/{presentationId}/pages/{pageObjectId}","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.slides","resource_name":"slides.presentations.pages.get"},{"hostname":"slides.googleapis.com","http_method":"GET","path_template":"/v1/presentations/{presentationId}/pages/{pageObjectId}/thumbnail","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/thumbnail)$","service_name":"google.slides","resource_name":"slides.presentations.pages.getThumbnail"},{"hostname":"slides.googleapis.com","http_method":"GET","path_template":"/v1/presentations/{presentationsId}","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.slides","resource_name":"slides.presentations.get"},{"hostname":"slides.googleapis.com","http_method":"POST","path_template":"/v1/presentations","path_regex":"^(?:/v1/presentations)$","service_name":"google.slides","resource_name":"slides.presentations.create"},{"hostname":"slides.googleapis.com","http_method":"POST","path_template":"/v1/presentations/{presentationId}:batchUpdate","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.slides","resource_name":"slides.presentations.batchUpdate"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.devices.list"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.devices.get"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.list"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures/{structuresId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.get"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures/{structuresId}/rooms","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rooms)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.rooms.list"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures/{structuresId}/rooms/{roomsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rooms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.rooms.get"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}:executeCommand","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeCommand)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.devices.executeCommand"},{"hostname":"sourcerepo.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/repos/{reposId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.delete"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.getConfig"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.list"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/repos/{reposId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.get"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/repos/{reposId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.getIamPolicy"},{"hostname":"sourcerepo.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.updateConfig"},{"hostname":"sourcerepo.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/repos/{reposId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.patch"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.create"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos/{reposId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.setIamPolicy"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos/{reposId}:sync","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sync)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.sync"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos/{reposId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.dropDatabase"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigOperations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigOperations)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigOperations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backupOperations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupOperations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backupOperations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databaseOperations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databaseOperations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databaseOperations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/databaseRoles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databaseRoles)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.databaseRoles.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/ddl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ddl)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.getDdl"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/scans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.getScans"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/scans","path_regex":"^(?:/v1/scans)$","service_name":"google.spanner","resource_name":"spanner.scans.list"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/ddl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ddl)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.updateDdl"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.getIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.setIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups:copy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups:copy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.copy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/databaseRoles/{databaseRolesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databaseRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.databaseRoles.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:beginTransaction","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::beginTransaction)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.beginTransaction"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.commit"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:executeBatchDml","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeBatchDml)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.executeBatchDml"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:executeSql","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeSql)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.executeSql"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:executeStreamingSql","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeStreamingSql)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.executeStreamingSql"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:partitionQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionQuery)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.partitionQuery"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:partitionRead","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionRead)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.partitionRead"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:read","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::read)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.read"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.rollback"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:streamingRead","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamingRead)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.streamingRead"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions:batchCreate)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.batchCreate"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.getIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.setIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases:restore)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.restore"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.getIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.setIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.testIamPermissions"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.delete"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.delete"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.delete"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.delete"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.speech","resource_name":"speech.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.speech","resource_name":"speech.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/operations","path_regex":"^(?:/v1p1beta1/operations)$","service_name":"google.speech","resource_name":"speech.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/operations/{operationsId}","path_regex":"^(?:/v1p1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.get"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.patch"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.patch"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.patch"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.patch"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/speech:longrunningrecognize","path_regex":"^(?:/v1/speech:longrunningrecognize)$","service_name":"google.speech","resource_name":"speech.speech.longrunningrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/speech:recognize","path_regex":"^(?:/v1/speech:recognize)$","service_name":"google.speech","resource_name":"speech.speech.recognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1beta1/speech:asyncrecognize","path_regex":"^(?:/v1beta1/speech:asyncrecognize)$","service_name":"google.speech","resource_name":"speech.speech.asyncrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1beta1/speech:syncrecognize","path_regex":"^(?:/v1beta1/speech:syncrecognize)$","service_name":"google.speech","resource_name":"speech.speech.syncrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/speech:longrunningrecognize","path_regex":"^(?:/v1p1beta1/speech:longrunningrecognize)$","service_name":"google.speech","resource_name":"speech.speech.longrunningrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/speech:recognize","path_regex":"^(?:/v1p1beta1/speech:recognize)$","service_name":"google.speech","resource_name":"speech.speech.recognize"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.backupRuns.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.sslCerts.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/flags","path_regex":"^(?:/sql/v1beta4/flags)$","service_name":"google.sql","resource_name":"sql.flags.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/flags","path_regex":"^(?:/sql/v1beta4/flags)$","service_name":"google.sqladmin","resource_name":"sql.flags.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sql","resource_name":"sql.instances.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sql","resource_name":"sql.backupRuns.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.backupRuns.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/connectSettings","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectSettings)$","service_name":"google.sqladmin","resource_name":"sql.connect.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sql","resource_name":"sql.databases.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/getDiskShrinkConfig","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiskShrinkConfig)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.getDiskShrinkConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/listServerCas","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listServerCas)$","service_name":"google.sql","resource_name":"sql.instances.listServerCas"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/listServerCas","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listServerCas)$","service_name":"google.sqladmin","resource_name":"sql.instances.listServerCas"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sql","resource_name":"sql.sslCerts.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.sslCerts.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users/{name}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.users.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.sql","resource_name":"sql.operations.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.sqladmin","resource_name":"sql.operations.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations/{operation}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.operations.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations/{operation}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.operations.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/tiers","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tiers)$","service_name":"google.sql","resource_name":"sql.tiers.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/tiers","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tiers)$","service_name":"google.sqladmin","resource_name":"sql.tiers.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/flags","path_regex":"^(?:/v1/flags)$","service_name":"google.sqladmin","resource_name":"sql.flags.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/connectSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectSettings)$","service_name":"google.sqladmin","resource_name":"sql.connect.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/getDiskShrinkConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiskShrinkConfig)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.getDiskShrinkConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/listServerCas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listServerCas)$","service_name":"google.sqladmin","resource_name":"sql.instances.listServerCas"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/users/{name}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.users.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.sqladmin","resource_name":"sql.operations.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/operations/{operation}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.operations.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/tiers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tiers)$","service_name":"google.sqladmin","resource_name":"sql.tiers.list"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sql","resource_name":"sql.instances.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/addServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addServerCa)$","service_name":"google.sql","resource_name":"sql.instances.addServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/addServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.addServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sql","resource_name":"sql.backupRuns.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/clone","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clone)$","service_name":"google.sql","resource_name":"sql.instances.clone"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/clone","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clone)$","service_name":"google.sqladmin","resource_name":"sql.instances.clone"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/createEphemeral","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEphemeral)$","service_name":"google.sql","resource_name":"sql.sslCerts.createEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/createEphemeral","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEphemeral)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.createEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sql","resource_name":"sql.databases.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/demoteMaster","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demoteMaster)$","service_name":"google.sql","resource_name":"sql.instances.demoteMaster"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/demoteMaster","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demoteMaster)$","service_name":"google.sqladmin","resource_name":"sql.instances.demoteMaster"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/export","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.sql","resource_name":"sql.instances.export"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/export","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.sqladmin","resource_name":"sql.instances.export"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/failover","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/failover)$","service_name":"google.sql","resource_name":"sql.instances.failover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/failover","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/failover)$","service_name":"google.sqladmin","resource_name":"sql.instances.failover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/import","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.sql","resource_name":"sql.instances.import"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/import","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.sqladmin","resource_name":"sql.instances.import"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/performDiskShrink","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performDiskShrink)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.performDiskShrink"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/promoteReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promoteReplica)$","service_name":"google.sql","resource_name":"sql.instances.promoteReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/promoteReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promoteReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.promoteReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rescheduleMaintenance","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rescheduleMaintenance)$","service_name":"google.sql","resource_name":"sql.projects.instances.rescheduleMaintenance"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rescheduleMaintenance","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rescheduleMaintenance)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.rescheduleMaintenance"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/resetReplicaSize","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetReplicaSize)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.resetReplicaSize"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/resetSslConfig","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetSslConfig)$","service_name":"google.sql","resource_name":"sql.instances.resetSslConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/resetSslConfig","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetSslConfig)$","service_name":"google.sqladmin","resource_name":"sql.instances.resetSslConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restart","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.sql","resource_name":"sql.instances.restart"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restart","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.sqladmin","resource_name":"sql.instances.restart"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restoreBackup","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restoreBackup)$","service_name":"google.sql","resource_name":"sql.instances.restoreBackup"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restoreBackup","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restoreBackup)$","service_name":"google.sqladmin","resource_name":"sql.instances.restoreBackup"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rotateServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rotateServerCa)$","service_name":"google.sql","resource_name":"sql.instances.rotateServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rotateServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rotateServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.rotateServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sql","resource_name":"sql.sslCerts.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startExternalSync","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startExternalSync)$","service_name":"google.sql","resource_name":"sql.projects.instances.startExternalSync"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startExternalSync","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startExternalSync)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.startExternalSync"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startReplica)$","service_name":"google.sql","resource_name":"sql.instances.startReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.startReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/stopReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopReplica)$","service_name":"google.sql","resource_name":"sql.instances.stopReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/stopReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.stopReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/truncateLog","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/truncateLog)$","service_name":"google.sql","resource_name":"sql.instances.truncateLog"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/truncateLog","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/truncateLog)$","service_name":"google.sqladmin","resource_name":"sql.instances.truncateLog"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/verifyExternalSyncSettings","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyExternalSyncSettings)$","service_name":"google.sql","resource_name":"sql.projects.instances.verifyExternalSyncSettings"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/verifyExternalSyncSettings","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyExternalSyncSettings)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.verifyExternalSyncSettings"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}:generateEphemeralCert","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateEphemeralCert)$","service_name":"google.sqladmin","resource_name":"sql.connect.generateEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/addServerCa","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.addServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/clone","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clone)$","service_name":"google.sqladmin","resource_name":"sql.instances.clone"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/createEphemeral","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEphemeral)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.createEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/demoteMaster","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demoteMaster)$","service_name":"google.sqladmin","resource_name":"sql.instances.demoteMaster"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.sqladmin","resource_name":"sql.instances.export"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/failover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/failover)$","service_name":"google.sqladmin","resource_name":"sql.instances.failover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.sqladmin","resource_name":"sql.instances.import"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/performDiskShrink","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performDiskShrink)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.performDiskShrink"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/promoteReplica","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promoteReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.promoteReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/rescheduleMaintenance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rescheduleMaintenance)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.rescheduleMaintenance"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/resetReplicaSize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetReplicaSize)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.resetReplicaSize"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/resetSslConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetSslConfig)$","service_name":"google.sqladmin","resource_name":"sql.instances.resetSslConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.sqladmin","resource_name":"sql.instances.restart"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/restoreBackup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restoreBackup)$","service_name":"google.sqladmin","resource_name":"sql.instances.restoreBackup"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/rotateServerCa","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rotateServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.rotateServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/startExternalSync","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startExternalSync)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.startExternalSync"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/startReplica","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.startReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/stopReplica","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.stopReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/truncateLog","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/truncateLog)$","service_name":"google.sqladmin","resource_name":"sql.instances.truncateLog"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/verifyExternalSyncSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyExternalSyncSettings)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.verifyExternalSyncSettings"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}:generateEphemeralCert","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateEphemeralCert)$","service_name":"google.sqladmin","resource_name":"sql.connect.generateEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.update"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/notificationConfigs/{notification}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.notifications.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/projects/{projectId}/hmacKeys/{accessId}","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b","path_regex":"^(?:/storage/v1/b)$","service_name":"google.storage","resource_name":"storage.buckets.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.buckets.getIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/iam/testPermissions","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam/testPermissions)$","service_name":"google.storage","resource_name":"storage.buckets.testIamPermissions"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/notificationConfigs","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.storage","resource_name":"storage.notifications.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/notificationConfigs/{notification}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.notifications.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.objects.getIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/iam/testPermissions","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam/testPermissions)$","service_name":"google.storage","resource_name":"storage.objects.testIamPermissions"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/projects/{projectId}/hmacKeys","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys)$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/projects/{projectId}/hmacKeys/{accessId}","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/projects/{projectId}/serviceAccount","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.storage","resource_name":"storage.projects.serviceAccount.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b","path_regex":"^(?:/storage/v1beta2/b)$","service_name":"google.storage","resource_name":"storage.buckets.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b","path_regex":"^(?:/storage/v1/b)$","service_name":"google.storage","resource_name":"storage.buckets.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/lockRetentionPolicy","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lockRetentionPolicy)$","service_name":"google.storage","resource_name":"storage.buckets.lockRetentionPolicy"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/notificationConfigs","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.storage","resource_name":"storage.notifications.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o/watch","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/watch)$","service_name":"google.storage","resource_name":"storage.objects.watchAll"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{destinationBucket}/o/{destinationObject}/compose","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compose)$","service_name":"google.storage","resource_name":"storage.objects.compose"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{sourceBucket}/o/{sourceObject}/copyTo/b/{destinationBucket}/o/{destinationObject}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyTo/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.copy"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{sourceBucket}/o/{sourceObject}/rewriteTo/b/{destinationBucket}/o/{destinationObject}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rewriteTo/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.rewrite"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/channels/stop","path_regex":"^(?:/storage/v1/channels/stop)$","service_name":"google.storage","resource_name":"storage.channels.stop"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/projects/{projectId}/hmacKeys","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys)$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.create"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b","path_regex":"^(?:/storage/v1beta2/b)$","service_name":"google.storage","resource_name":"storage.buckets.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/o","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/o/watch","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/watch)$","service_name":"google.storage","resource_name":"storage.objects.watchAll"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{destinationBucket}/o/{destinationObject}/compose","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compose)$","service_name":"google.storage","resource_name":"storage.objects.compose"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{sourceBucket}/o/{sourceObject}/copyTo/b/{destinationBucket}/o/{destinationObject}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyTo/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.copy"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/channels/stop","path_regex":"^(?:/storage/v1beta2/channels/stop)$","service_name":"google.storage","resource_name":"storage.channels.stop"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.buckets.setIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/o/{object}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.objects.setIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/projects/{projectId}/hmacKeys/{accessId}","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.update"},{"hostname":"storagetransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/agentPools/{agentPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.delete"},{"hostname":"storagetransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/transferJobs/{transferJobsId}","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.delete"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/googleServiceAccounts/{projectId}","path_regex":"^(?:/v1/googleServiceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.googleServiceAccounts.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/agentPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.list"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/agentPools/{agentPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferJobs","path_regex":"^(?:/v1/transferJobs)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.list"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferJobs/{transferJobsId}","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferOperations","path_regex":"^(?:/v1/transferOperations)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.list"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferOperations/{transferOperationsId}","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/agentPools/{agentPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.patch"},{"hostname":"storagetransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/transferJobs/{transferJobsId}","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.patch"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/agentPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.create"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferJobs","path_regex":"^(?:/v1/transferJobs)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.create"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferJobs/{transferJobsId}:run","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.run"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferOperations/{transferOperationsId}:cancel","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.cancel"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferOperations/{transferOperationsId}:pause","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.pause"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferOperations/{transferOperationsId}:resume","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.resume"},{"hostname":"streetviewpublish.googleapis.com","http_method":"DELETE","path_template":"/v1/photo/{photoId}","path_regex":"^(?:/v1/photo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.delete"},{"hostname":"streetviewpublish.googleapis.com","http_method":"DELETE","path_template":"/v1/photoSequence/{sequenceId}","path_regex":"^(?:/v1/photoSequence/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.delete"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photo/{photoId}","path_regex":"^(?:/v1/photo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.get"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photoSequence/{sequenceId}","path_regex":"^(?:/v1/photoSequence/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.get"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photoSequences","path_regex":"^(?:/v1/photoSequences)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequences.list"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photos","path_regex":"^(?:/v1/photos)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.list"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photos:batchGet","path_regex":"^(?:/v1/photos:batchGet)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.batchGet"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photo","path_regex":"^(?:/v1/photo)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.create"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photo:startUpload","path_regex":"^(?:/v1/photo:startUpload)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.startUpload"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photoSequence","path_regex":"^(?:/v1/photoSequence)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.create"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photoSequence:startUpload","path_regex":"^(?:/v1/photoSequence:startUpload)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.startUpload"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photos:batchDelete","path_regex":"^(?:/v1/photos:batchDelete)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.batchDelete"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photos:batchUpdate","path_regex":"^(?:/v1/photos:batchUpdate)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.batchUpdate"},{"hostname":"streetviewpublish.googleapis.com","http_method":"PUT","path_template":"/v1/photo/{id}","path_regex":"^(?:/v1/photo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.update"},{"hostname":"sts.googleapis.com","http_method":"POST","path_template":"/v1/introspect","path_regex":"^(?:/v1/introspect)$","service_name":"google.sts","resource_name":"sts.introspect"},{"hostname":"sts.googleapis.com","http_method":"POST","path_template":"/v1/oauthtoken","path_regex":"^(?:/v1/oauthtoken)$","service_name":"google.sts","resource_name":"sts.oauthtoken"},{"hostname":"sts.googleapis.com","http_method":"POST","path_template":"/v1/token","path_regex":"^(?:/v1/token)$","service_name":"google.sts","resource_name":"sts.token"},{"hostname":"sts.googleapis.com","http_method":"POST","path_template":"/v1beta/token","path_regex":"^(?:/v1beta/token)$","service_name":"google.sts","resource_name":"sts.token"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags/{tagId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers/{triggerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables/{variableId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/permissions/{permissionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config/{gtag_configId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions/{user_permissionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts","path_regex":"^(?:/tagmanager/v1/accounts)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}/entities","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.entities.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags/{tagId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers/{triggerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables/{variableId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/permissions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/permissions/{permissionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts","path_regex":"^(?:/tagmanager/v2/accounts)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/containers:lookup","path_regex":"^(?:/tagmanager/v2/accounts/containers:lookup)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.lookup"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/destinations","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destinations)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.destinations.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/destinations/{destinationsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destinations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.destinations.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/version_headers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/version_headers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.version_headers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/version_headers:latest","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/version_headers:latest)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.version_headers.latest"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions:live","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:live)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.live"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config/{gtag_configId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/status","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/status)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.getStatus"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}:snippet","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::snippet)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.snippet"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions/{user_permissionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}/publish","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.publish"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}/restore","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restore)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.restore"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}/undelete","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/undelete)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.undelete"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/permissions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/destinations:link","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destinations:link)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.destinations.link"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}:reauthorize","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reauthorize)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.reauthorize"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}:publish","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.publish"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}:set_latest","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::set_latest)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.set_latest"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}:undelete","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.undelete"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables:revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}:entities","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::entities)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.entities"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}:move_entities_to_folder","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move_entities_to_folder)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.move_entities_to_folder"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:create_version","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::create_version)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.create_version"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:quick_preview","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::quick_preview)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.quick_preview"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:resolve_conflict","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve_conflict)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.resolve_conflict"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:sync","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sync)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.sync"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}:combine","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::combine)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.combine"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}:move_tag_id","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move_tag_id)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.move_tag_id"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.create"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/move_folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move_folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.move_folders.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/reauthorize_environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reauthorize_environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.reauthorize_environments.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags/{tagId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers/{triggerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables/{variableId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/permissions/{permissionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config/{gtag_configId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions/{user_permissionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.update"},{"hostname":"tasks.googleapis.com","http_method":"DELETE","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.delete"},{"hostname":"tasks.googleapis.com","http_method":"DELETE","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.delete"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/lists/{tasklist}/tasks","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.tasks","resource_name":"tasks.tasks.list"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.get"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/users/@me/lists","path_regex":"^(?:/tasks/v1/users/@me/lists)$","service_name":"google.tasks","resource_name":"tasks.tasklists.list"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.get"},{"hostname":"tasks.googleapis.com","http_method":"PATCH","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.patch"},{"hostname":"tasks.googleapis.com","http_method":"PATCH","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.patch"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/lists/{tasklist}/clear","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clear)$","service_name":"google.tasks","resource_name":"tasks.tasks.clear"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/lists/{tasklist}/tasks","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.tasks","resource_name":"tasks.tasks.insert"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}/move","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.tasks","resource_name":"tasks.tasks.move"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/users/@me/lists","path_regex":"^(?:/tasks/v1/users/@me/lists)$","service_name":"google.tasks","resource_name":"tasks.tasklists.insert"},{"hostname":"tasks.googleapis.com","http_method":"PUT","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.update"},{"hostname":"tasks.googleapis.com","http_method":"PUT","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.update"},{"hostname":"testing.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/testMatrices/{testMatrixId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testMatrices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.testing","resource_name":"testing.projects.testMatrices.get"},{"hostname":"testing.googleapis.com","http_method":"GET","path_template":"/v1/testEnvironmentCatalog/{environmentType}","path_regex":"^(?:/v1/testEnvironmentCatalog/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.testing","resource_name":"testing.testEnvironmentCatalog.get"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/applicationDetailService/getApkDetails","path_regex":"^(?:/v1/applicationDetailService/getApkDetails)$","service_name":"google.testing","resource_name":"testing.applicationDetailService.getApkDetails"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/testMatrices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testMatrices)$","service_name":"google.testing","resource_name":"testing.projects.testMatrices.create"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/testMatrices/{testMatrixId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testMatrices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.testing","resource_name":"testing.projects.testMatrices.cancel"},{"hostname":"texttospeech.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.texttospeech","resource_name":"texttospeech.operations.delete"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.list"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.get"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1/voices","path_regex":"^(?:/v1/voices)$","service_name":"google.texttospeech","resource_name":"texttospeech.voices.list"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.list"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.get"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1beta1/voices","path_regex":"^(?:/v1beta1/voices)$","service_name":"google.texttospeech","resource_name":"texttospeech.voices.list"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.texttospeech","resource_name":"texttospeech.operations.cancel"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:synthesizeLongAudio","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::synthesizeLongAudio)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.synthesizeLongAudio"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1/text:synthesize","path_regex":"^(?:/v1/text:synthesize)$","service_name":"google.texttospeech","resource_name":"texttospeech.text.synthesize"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}:synthesizeLongAudio","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::synthesizeLongAudio)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.synthesizeLongAudio"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1beta1/text:synthesize","path_regex":"^(?:/v1beta1/text:synthesize)$","service_name":"google.texttospeech","resource_name":"texttospeech.text.synthesize"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/clusters","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.clusters.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/clusters/{clusterId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.clusters.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/environments","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.environments.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/environments/{environmentId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.environments.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfMetricsSummary","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfMetricsSummary)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.getPerfMetricsSummary"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries/{sampleSeriesId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries/{sampleSeriesId}/samples","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/samples)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.samples.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/testCases","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.testCases.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/testCases/{testCaseId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.testCases.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/thumbnails","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/thumbnails)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.thumbnails.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/settings","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.toolresults","resource_name":"toolresults.projects.getSettings"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectsId}/histories/{historiesId}/executions/{executionsId}/steps/{stepsId}:accessibilityClusters","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accessibilityClusters)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.accessibilityClusters"},{"hostname":"toolresults.googleapis.com","http_method":"PATCH","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.patch"},{"hostname":"toolresults.googleapis.com","http_method":"PATCH","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.patch"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfMetricsSummary","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfMetricsSummary)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfMetricsSummary.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries/{sampleSeriesId}/samples:batchCreate","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/samples:batchCreate)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.samples.batchCreate"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}:publishXunitXmlFiles","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publishXunitXmlFiles)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.publishXunitXmlFiles"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}:initializeSettings","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initializeSettings)$","service_name":"google.toolresults","resource_name":"toolresults.projects.initializeSettings"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.delete"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions/{tensorflowVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions/{tensorflowVersionsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/runtimeVersions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/runtimeVersions/{runtimeVersionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/runtimeVersions","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/runtimeVersions/{runtimeVersionsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.patch"},{"hostname":"tpu.googleapis.com","http_method":"PATCH","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.patch"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:reimage","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reimage)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.reimage"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:reimage","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reimage)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.reimage"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:getGuestAttributes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getGuestAttributes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.getGuestAttributes"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}:generateServiceIdentity","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateServiceIdentity)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.generateServiceIdentity"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:getGuestAttributes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getGuestAttributes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.getGuestAttributes"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:simulateMaintenanceEvent","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::simulateMaintenanceEvent)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.simulateMaintenanceEvent"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}:generateServiceIdentity","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateServiceIdentity)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.generateServiceIdentity"},{"hostname":"tracing.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/traces","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces)$","service_name":"google.tracing","resource_name":"tracing.projects.traces.list"},{"hostname":"tracing.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/traces/{tracesId}:listSpans","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSpans)$","service_name":"google.tracing","resource_name":"tracing.projects.traces.listSpans"},{"hostname":"tracing.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/traces:batchWrite","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces:batchWrite)$","service_name":"google.tracing","resource_name":"tracing.projects.traces.batchWrite"},{"hostname":"tracing.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/traces/{tracesId}/spans/{spansId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tracing","resource_name":"tracing.projects.traces.spans.create"},{"hostname":"trafficdirector.googleapis.com","http_method":"POST","path_template":"/v2/discovery:client_status","path_regex":"^(?:/v2/discovery:client_status)$","service_name":"google.trafficdirector","resource_name":"trafficdirector.discovery.client_status"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.delete"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.delete"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.delete"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.delete"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.get"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.get"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.get"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.get"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.create"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.create"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.create"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.create"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries/{glossaryEntriesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.models.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.delete"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/language/translate/v2","path_regex":"^(?:/language/translate/v2)$","service_name":"google.translate","resource_name":"language.translations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/language/translate/v2/detect","path_regex":"^(?:/language/translate/v2/detect)$","service_name":"google.translate","resource_name":"language.detections.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/language/translate/v2/languages","path_regex":"^(?:/language/translate/v2/languages)$","service_name":"google.translate","resource_name":"language.languages.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.translate","resource_name":"translate.projects.locations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/examples","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.examples.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries/{glossaryEntriesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.translate","resource_name":"translate.projects.locations.models.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.models.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/supportedLanguages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.locations.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/supportedLanguages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.translate","resource_name":"translate.projects.locations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/supportedLanguages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.locations.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/supportedLanguages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.patch"},{"hostname":"translation.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries/{glossaryEntriesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.patch"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/language/translate/v2","path_regex":"^(?:/language/translate/v2)$","service_name":"google.translate","resource_name":"language.translations.translate"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/language/translate/v2/detect","path_regex":"^(?:/language/translate/v2/detect)$","service_name":"google.translate","resource_name":"language.detections.detect"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:exportData","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportData)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.exportData"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:importData","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importData)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.importData"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.translate","resource_name":"translate.projects.locations.models.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.cancel"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.wait"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:batchTranslateDocument","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:batchTranslateText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:detectLanguage","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.locations.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:translateDocument","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:translateText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:detectLanguage","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:translateText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.translateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.cancel"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.wait"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:batchTranslateDocument","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:batchTranslateText","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:detectLanguage","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.locations.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:translateDocument","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:translateText","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}:detectLanguage","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}:translateText","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.translateText"},{"hostname":"travelimpactmodel.googleapis.com","http_method":"POST","path_template":"/v1/flights:computeFlightEmissions","path_regex":"^(?:/v1/flights:computeFlightEmissions)$","service_name":"google.travelimpactmodel","resource_name":"travelimpactmodel.flights.computeFlightEmissions"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/exports/{exportId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.exports.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/holds/{holdId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/holds/{holdId}/accounts/{accountId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.accounts.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/savedQueries/{savedQueryId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.operations.delete"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters","path_regex":"^(?:/v1/matters)$","service_name":"google.vault","resource_name":"vault.matters.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/exports","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports)$","service_name":"google.vault","resource_name":"vault.matters.exports.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/exports/{exportId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.exports.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/holds","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds)$","service_name":"google.vault","resource_name":"vault.matters.holds.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/holds/{holdId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/holds/{holdId}/accounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.accounts.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/savedQueries","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/savedQueries/{savedQueryId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.vault","resource_name":"vault.operations.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.operations.get"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters","path_regex":"^(?:/v1/matters)$","service_name":"google.vault","resource_name":"vault.matters.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/exports","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports)$","service_name":"google.vault","resource_name":"vault.matters.exports.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds)$","service_name":"google.vault","resource_name":"vault.matters.holds.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds/{holdId}/accounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.accounts.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds/{holdId}:addHeldAccounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addHeldAccounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.addHeldAccounts"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds/{holdId}:removeHeldAccounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeHeldAccounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.removeHeldAccounts"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/savedQueries","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:addPermissions","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addPermissions)$","service_name":"google.vault","resource_name":"vault.matters.addPermissions"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:close","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.vault","resource_name":"vault.matters.close"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:count","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::count)$","service_name":"google.vault","resource_name":"vault.matters.count"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:removePermissions","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removePermissions)$","service_name":"google.vault","resource_name":"vault.matters.removePermissions"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:reopen","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reopen)$","service_name":"google.vault","resource_name":"vault.matters.reopen"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:undelete","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.vault","resource_name":"vault.matters.undelete"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vault","resource_name":"vault.operations.cancel"},{"hostname":"vault.googleapis.com","http_method":"PUT","path_template":"/v1/matters/{matterId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.update"},{"hostname":"vault.googleapis.com","http_method":"PUT","path_template":"/v1/matters/{matterId}/holds/{holdId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.update"},{"hostname":"vectortile.googleapis.com","http_method":"GET","path_template":"/v1/featuretiles/{featuretilesId}","path_regex":"^(?:/v1/featuretiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vectortile","resource_name":"vectortile.featuretiles.get"},{"hostname":"vectortile.googleapis.com","http_method":"GET","path_template":"/v1/terraintiles/{terraintilesId}","path_regex":"^(?:/v1/terraintiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vectortile","resource_name":"vectortile.terraintiles.get"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v1/challenge","path_regex":"^(?:/v1/challenge)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.create"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v1/challenge:verify","path_regex":"^(?:/v1/challenge:verify)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.verify"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v2/challenge:generate","path_regex":"^(?:/v2/challenge:generate)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.generate"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v2/challenge:verify","path_regex":"^(?:/v2/challenge:verify)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.verify"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.list"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms/{platformsId}/channels","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.channels.list"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms/{platformsId}/channels/{channelsId}/versions","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.channels.versions.list"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms/{platformsId}/channels/{channelsId}/versions/{versionsId}/releases","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.channels.versions.releases.list"},{"hostname":"videointelligence.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.operations.projects.locations.operations.delete"},{"hostname":"videointelligence.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.delete"},{"hostname":"videointelligence.googleapis.com","http_method":"GET","path_template":"/v1/operations/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.operations.projects.locations.operations.get"},{"hostname":"videointelligence.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.list"},{"hostname":"videointelligence.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.get"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1/operations/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.videointelligence","resource_name":"videointelligence.operations.projects.locations.operations.cancel"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.cancel"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1/videos:annotate","path_regex":"^(?:/v1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1beta2/videos:annotate","path_regex":"^(?:/v1beta2/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/videos:annotate","path_regex":"^(?:/v1p1beta1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/videos:annotate","path_regex":"^(?:/v1p2beta1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1p3beta1/videos:annotate","path_regex":"^(?:/v1p3beta1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.operations.delete"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.delete"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.delete"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages/{referenceImagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.delete"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.locations.operations.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.vision","resource_name":"vision.operations.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.operations.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.operations.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}/products","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.products.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages/{referenceImagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.operations.get"},{"hostname":"vision.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.patch"},{"hostname":"vision.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.patch"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/files:annotate","path_regex":"^(?:/v1/files:annotate)$","service_name":"google.vision","resource_name":"vision.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/files:asyncBatchAnnotate","path_regex":"^(?:/v1/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/images:annotate","path_regex":"^(?:/v1/images:annotate)$","service_name":"google.vision","resource_name":"vision.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/images:asyncBatchAnnotate","path_regex":"^(?:/v1/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vision","resource_name":"vision.operations.cancel"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/files:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/images:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/files:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/images:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.create"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}:addProduct","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addProduct)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.addProduct"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}:removeProduct","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeProduct)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.removeProduct"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets:import)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.import"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.create"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.create"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:purge)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.purge"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/files:annotate","path_regex":"^(?:/v1p1beta1/files:annotate)$","service_name":"google.vision","resource_name":"vision.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/files:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/images:annotate","path_regex":"^(?:/v1p1beta1/images:annotate)$","service_name":"google.vision","resource_name":"vision.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/images:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/files:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/images:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/files:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/images:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/files:annotate","path_regex":"^(?:/v1p2beta1/files:annotate)$","service_name":"google.vision","resource_name":"vision.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/files:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/images:annotate","path_regex":"^(?:/v1p2beta1/images:annotate)$","service_name":"google.vision","resource_name":"vision.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/images:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/files:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/images:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/files:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/images:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.asyncBatchAnnotate"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles/{replicationCyclesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}:fetchInventory","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchInventory)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.fetchInventory"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles/{replicationCyclesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}:fetchInventory","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchInventory)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.fetchInventory"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.get"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:addGroupMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.addGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:removeGroupMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.removeGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}:upgradeAppliance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgradeAppliance)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.upgradeAppliance"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:finalizeMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::finalizeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.finalizeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:pauseMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pauseMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.pauseMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:resumeMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resumeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.resumeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:startMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.startMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:addGroupMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.addGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:removeGroupMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.removeGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}:upgradeAppliance","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgradeAppliance)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.upgradeAppliance"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:finalizeMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::finalizeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.finalizeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:pauseMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pauseMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.pauseMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:resumeMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resumeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.resumeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:startMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.startMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.create"},{"hostname":"vpcaccess.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.delete"},{"hostname":"vpcaccess.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.delete"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.patch"},{"hostname":"vpcaccess.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.patch"},{"hostname":"vpcaccess.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.create"},{"hostname":"vpcaccess.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.create"},{"hostname":"webfonts.googleapis.com","http_method":"GET","path_template":"/v1/webfonts","path_regex":"^(?:/v1/webfonts)$","service_name":"google.webfonts","resource_name":"webfonts.webfonts.list"},{"hostname":"webrisk.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.delete"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/hashes:search","path_regex":"^(?:/v1/hashes:search)$","service_name":"google.webrisk","resource_name":"webrisk.hashes.search"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.list"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.get"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/threatLists:computeDiff","path_regex":"^(?:/v1/threatLists:computeDiff)$","service_name":"google.webrisk","resource_name":"webrisk.threatLists.computeDiff"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/uris:search","path_regex":"^(?:/v1/uris:search)$","service_name":"google.webrisk","resource_name":"webrisk.uris.search"},{"hostname":"webrisk.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.cancel"},{"hostname":"webrisk.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/submissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/submissions)$","service_name":"google.webrisk","resource_name":"webrisk.projects.submissions.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.delete"},{"hostname":"websecurityscanner.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.delete"},{"hostname":"websecurityscanner.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.delete"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/crawledUrls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crawledUrls)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.crawledUrls.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findingTypeStats","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findingTypeStats)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findingTypeStats.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings/{findingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/crawledUrls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crawledUrls)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.crawledUrls.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findingTypeStats","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findingTypeStats)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findingTypeStats.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings/{findingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/crawledUrls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crawledUrls)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.crawledUrls.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findingTypeStats","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findingTypeStats)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findingTypeStats.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings/{findingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.patch"},{"hostname":"websecurityscanner.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.patch"},{"hostname":"websecurityscanner.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.patch"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.stop"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.start"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}:stop","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.stop"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}:start","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.start"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}:stop","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.stop"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}:start","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.start"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.list"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.get"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.list"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.get"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.create"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.cancel"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}:triggerPubsubExecution","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::triggerPubsubExecution)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.triggerPubsubExecution"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.create"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.cancel"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.delete"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.delete"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.delete"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.delete"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.get"},{"hostname":"workflows.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.patch"},{"hostname":"workflows.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.patch"},{"hostname":"workflows.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.create"},{"hostname":"workflows.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.create"},{"hostname":"workloadmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.delete"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions/{executionsId}/results","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.results.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions/{executionsId}/scannedResources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scannedResources)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.scannedResources.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/rules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.rules.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.create"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions:run)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.run"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insights:writeInsight","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights:writeInsight)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.insights.writeInsight"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.cancel"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.delete"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.getIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations:listUsable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations:listUsable)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.listUsable"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.getIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs:listUsable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs:listUsable)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.listUsable"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.patch"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.patch"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.patch"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.cancel"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:generateAccessToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAccessToken)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.generateAccessToken"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.setIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:start","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.start"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:stop","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.stop"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.testIamPermissions"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.setIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.testIamPermissions"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsense/v1.4/accounts/{accountId}/alerts/{alertId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsense/v1.4/alerts/{alertId}","path_regex":"^(?:/adsense/v1\\.4/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.alerts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsensehost/v4.1/adclients/{adClientId}/urlchannels/{urlChannelId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.urlchannels.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/appstate/v1/states/{stateKey}","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appstate","resource_name":"appstate.states.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/drives/{driveId}","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/trash","path_regex":"^(?:/drive/v2/files/trash)$","service_name":"google.drive","resource_name":"drive.files.emptyTrash"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/parents/{parentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.parents.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{folderId}/children/{childId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.children.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v2/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/drives/{driveId}","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/trash","path_regex":"^(?:/drive/v3/files/trash)$","service_name":"google.drive","resource_name":"drive.files.emptyTrash"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v3/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/subscriptions/{id}","path_regex":"^(?:/mirror/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.subscriptions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/timeline/{itemId}/attachments/{attachmentId}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/surveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.surveys","resource_name":"surveys.surveys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sites.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/youtube/analytics/v1beta1/groupItems","path_regex":"^(?:/youtube/analytics/v1beta1/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.delete"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/accounts","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.2/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/creatives/{accountId}/{buyerCreativeId}","path_regex":"^(?:/adexchangebuyer/v1\\.2/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/accounts","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/billinginfo","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.3/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/creatives/{accountId}/{buyerCreativeId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/directdeals","path_regex":"^(?:/adexchangebuyer/v1\\.3/directdeals)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.directDeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/directdeals/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/directdeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.directDeals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/performancereport","path_regex":"^(?:/adexchangebuyer/v1\\.3/performancereport)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.performanceReport.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/accounts","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/billinginfo","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}/listDeals","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listDeals)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.listDeals"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/performancereport","path_regex":"^(?:/adexchangebuyer/v1\\.4/performancereport)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.performanceReport.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/products/search","path_regex":"^(?:/adexchangebuyer/v1\\.4/products/search)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.products.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/products/{productId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.products.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/search","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/search)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/notes","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacenotes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/publisher/{accountId}/profiles","path_regex":"^(?:/adexchangebuyer/v1\\.4/publisher/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pubprofiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/accounts/{accountId}","path_regex":"^(?:/adexchangeseller/v1\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/adunits","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/alerts","path_regex":"^(?:/adexchangeseller/v1\\.1/alerts)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/metadata/dimensions","path_regex":"^(?:/adexchangeseller/v1\\.1/metadata/dimensions)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/metadata/metrics","path_regex":"^(?:/adexchangeseller/v1\\.1/metadata/metrics)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/preferreddeals","path_regex":"^(?:/adexchangeseller/v1\\.1/preferreddeals)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.preferreddeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/preferreddeals/{dealId}","path_regex":"^(?:/adexchangeseller/v1\\.1/preferreddeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.preferreddeals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/reports","path_regex":"^(?:/adexchangeseller/v1\\.1/reports)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/reports/saved","path_regex":"^(?:/adexchangeseller/v1\\.1/reports/saved)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/reports/{savedReportId}","path_regex":"^(?:/adexchangeseller/v1\\.1/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients","path_regex":"^(?:/adexchangeseller/v1/adclients)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/adunits","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/reports","path_regex":"^(?:/adexchangeseller/v1/reports)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/reports/saved","path_regex":"^(?:/adexchangeseller/v1/reports/saved)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/reports/{savedReportId}","path_regex":"^(?:/adexchangeseller/v1/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients/{adClientId}/customchannels","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/alerts","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/metadata/dimensions","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata/dimensions)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/metadata/metrics","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata/metrics)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/preferreddeals","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferreddeals)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.preferreddeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/preferreddeals/{dealId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferreddeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.preferreddeals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/reports","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/reports/saved","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/reports/{savedReportId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts","path_regex":"^(?:/adsense/v1\\.3/accounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/alerts","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/reports","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/reports/saved","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/savedadstyles","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients","path_regex":"^(?:/adsense/v1\\.3/adclients)$","service_name":"google.adsense","resource_name":"adsense.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/alerts","path_regex":"^(?:/adsense/v1\\.3/alerts)$","service_name":"google.adsense","resource_name":"adsense.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/metadata/dimensions","path_regex":"^(?:/adsense/v1\\.3/metadata/dimensions)$","service_name":"google.adsense","resource_name":"adsense.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/metadata/metrics","path_regex":"^(?:/adsense/v1\\.3/metadata/metrics)$","service_name":"google.adsense","resource_name":"adsense.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/reports","path_regex":"^(?:/adsense/v1\\.3/reports)$","service_name":"google.adsense","resource_name":"adsense.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/reports/saved","path_regex":"^(?:/adsense/v1\\.3/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.3/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/savedadstyles","path_regex":"^(?:/adsense/v1\\.3/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.3/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts","path_regex":"^(?:/adsense/v1\\.4/accounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adcode","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/alerts","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/payments","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/payments)$","service_name":"google.adsense","resource_name":"adsense.accounts.payments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/reports","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/reports/saved","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/savedadstyles","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients","path_regex":"^(?:/adsense/v1\\.4/adclients)$","service_name":"google.adsense","resource_name":"adsense.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/alerts","path_regex":"^(?:/adsense/v1\\.4/alerts)$","service_name":"google.adsense","resource_name":"adsense.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/metadata/dimensions","path_regex":"^(?:/adsense/v1\\.4/metadata/dimensions)$","service_name":"google.adsense","resource_name":"adsense.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/metadata/metrics","path_regex":"^(?:/adsense/v1\\.4/metadata/metrics)$","service_name":"google.adsense","resource_name":"adsense.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/payments","path_regex":"^(?:/adsense/v1\\.4/payments)$","service_name":"google.adsense","resource_name":"adsense.payments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/reports","path_regex":"^(?:/adsense/v1\\.4/reports)$","service_name":"google.adsense","resource_name":"adsense.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/reports/saved","path_regex":"^(?:/adsense/v1\\.4/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.4/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/savedadstyles","path_regex":"^(?:/adsense/v1\\.4/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.4/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts","path_regex":"^(?:/adsensehost/v4\\.1/accounts)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adclients.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/reports","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients","path_regex":"^(?:/adsensehost/v4\\.1/adclients)$","service_name":"google.adsensehost","resource_name":"adsensehost.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.adclients.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/associationsessions/start","path_regex":"^(?:/adsensehost/v4\\.1/associationsessions/start)$","service_name":"google.adsensehost","resource_name":"adsensehost.associationsessions.start"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/associationsessions/verify","path_regex":"^(?:/adsensehost/v4\\.1/associationsessions/verify)$","service_name":"google.adsensehost","resource_name":"adsensehost.associationsessions.verify"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/reports","path_regex":"^(?:/adsensehost/v4\\.1/reports)$","service_name":"google.adsensehost","resource_name":"adsensehost.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/data","path_regex":"^(?:/analytics/v2\\.4/data)$","service_name":"google.analytics","resource_name":"analytics.data.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts","path_regex":"^(?:/analytics/v2\\.4/management/accounts)$","service_name":"google.analytics","resource_name":"analytics.management.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts/{accountId}/webproperties","path_regex":"^(?:/analytics/v2\\.4/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties)$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles","path_regex":"^(?:/analytics/v2\\.4/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.analytics","resource_name":"analytics.management.profiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals","path_regex":"^(?:/analytics/v2\\.4/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals)$","service_name":"google.analytics","resource_name":"analytics.management.goals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/segments","path_regex":"^(?:/analytics/v2\\.4/management/segments)$","service_name":"google.analytics","resource_name":"analytics.management.segments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v1.1/applications/{packageName}/inapp/{productId}/purchases/{token}","path_regex":"^(?:/androidpublisher/v1\\.1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inapp/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inapppurchases.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v2/applications/{packageName}/purchases/products/{productId}/tokens/{token}","path_regex":"^(?:/androidpublisher/v2/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v2/applications/{packageName}/purchases/voidedpurchases","path_regex":"^(?:/androidpublisher/v2/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/voidedpurchases)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.voidedpurchases.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/appsactivity/v1/activities","path_regex":"^(?:/appsactivity/v1/activities)$","service_name":"google.appsactivity","resource_name":"appsactivity.activities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/appstate/v1/states","path_regex":"^(?:/appstate/v1/states)$","service_name":"google.appstate","resource_name":"appstate.states.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/appstate/v1/states/{stateKey}","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appstate","resource_name":"appstate.states.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/byurl","path_regex":"^(?:/blogger/v3/blogs/byurl)$","service_name":"google.blogger","resource_name":"blogger.blogs.getByUrl"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/comments","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.listByBlog"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/pages","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/pageviews","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pageviews)$","service_name":"google.blogger","resource_name":"blogger.pageViews.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/bypath","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/bypath)$","service_name":"google.blogger","resource_name":"blogger.posts.getByPath"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/search","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/search)$","service_name":"google.blogger","resource_name":"blogger.posts.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.users.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs)$","service_name":"google.blogger","resource_name":"blogger.blogs.listByUser"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs/{blogId}","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogUserInfos.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs/{blogId}/posts","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/acl","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.calendar","resource_name":"calendar.acl.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/events","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.calendar","resource_name":"calendar.events.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}/instances","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.calendar","resource_name":"calendar.events.instances"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/colors","path_regex":"^(?:/calendar/v3/colors)$","service_name":"google.calendar","resource_name":"calendar.colors.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/calendarList","path_regex":"^(?:/calendar/v3/users/me/calendarList)$","service_name":"google.calendar","resource_name":"calendar.calendarList.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/settings","path_regex":"^(?:/calendar/v3/users/me/settings)$","service_name":"google.calendar","resource_name":"calendar.settings.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/settings/{setting}","path_regex":"^(?:/calendar/v3/users/me/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.settings.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/mobileAppPanels","path_regex":"^(?:/consumersurveys/v2/mobileAppPanels)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.mobileapppanels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/mobileAppPanels/{panelId}","path_regex":"^(?:/consumersurveys/v2/mobileAppPanels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.mobileapppanels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/surveys","path_regex":"^(?:/consumersurveys/v2/surveys)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}/results","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.results.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orderreturns","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns)$","service_name":"google.content","resource_name":"content.orderreturns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orderreturns/{returnId}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orderreturns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orders","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.content","resource_name":"content.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/ordersbymerchantid/{merchantOrderId}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordersbymerchantid/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.getbymerchantorderid"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/testordertemplates/{templateName}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testordertemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.gettestordertemplate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v2\\.7/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySiteContacts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySiteContacts/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.0/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySiteContacts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySiteContacts/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.1/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.2/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySiteContacts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySiteContacts/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/discovery/v1/apis","path_regex":"^(?:/discovery/v1/apis)$","service_name":"google.discovery","resource_name":"discovery.apis.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/discovery/v1/apis/{api}/{version}/rest","path_regex":"^(?:/discovery/v1/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rest)$","service_name":"google.discovery","resource_name":"discovery.apis.getRest"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/about","path_regex":"^(?:/drive/v2/about)$","service_name":"google.drive","resource_name":"drive.about.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/apps","path_regex":"^(?:/drive/v2/apps)$","service_name":"google.drive","resource_name":"drive.apps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/apps/{appId}","path_regex":"^(?:/drive/v2/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.apps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/changes","path_regex":"^(?:/drive/v2/changes)$","service_name":"google.drive","resource_name":"drive.changes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/changes/startPageToken","path_regex":"^(?:/drive/v2/changes/startPageToken)$","service_name":"google.drive","resource_name":"drive.changes.getStartPageToken"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/changes/{changeId}","path_regex":"^(?:/drive/v2/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.changes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/drives","path_regex":"^(?:/drive/v2/drives)$","service_name":"google.drive","resource_name":"drive.drives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/drives/{driveId}","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files","path_regex":"^(?:/drive/v2/files)$","service_name":"google.drive","resource_name":"drive.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/generateIds","path_regex":"^(?:/drive/v2/files/generateIds)$","service_name":"google.drive","resource_name":"drive.files.generateIds"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/export","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.drive","resource_name":"drive.files.export"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/listLabels","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listLabels)$","service_name":"google.drive","resource_name":"drive.files.listLabels"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/parents","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents)$","service_name":"google.drive","resource_name":"drive.parents.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/parents/{parentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.parents.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/permissions","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/properties","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties)$","service_name":"google.drive","resource_name":"drive.properties.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/revisions","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.drive","resource_name":"drive.revisions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{folderId}/children","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children)$","service_name":"google.drive","resource_name":"drive.children.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{folderId}/children/{childId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.children.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/permissionIds/{email}","path_regex":"^(?:/drive/v2/permissionIds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.getIdForEmail"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/teamdrives","path_regex":"^(?:/drive/v2/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v2/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/about","path_regex":"^(?:/drive/v3/about)$","service_name":"google.drive","resource_name":"drive.about.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/changes","path_regex":"^(?:/drive/v3/changes)$","service_name":"google.drive","resource_name":"drive.changes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/changes/startPageToken","path_regex":"^(?:/drive/v3/changes/startPageToken)$","service_name":"google.drive","resource_name":"drive.changes.getStartPageToken"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/drives","path_regex":"^(?:/drive/v3/drives)$","service_name":"google.drive","resource_name":"drive.drives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/drives/{driveId}","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files","path_regex":"^(?:/drive/v3/files)$","service_name":"google.drive","resource_name":"drive.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/generateIds","path_regex":"^(?:/drive/v3/files/generateIds)$","service_name":"google.drive","resource_name":"drive.files.generateIds"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/export","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.drive","resource_name":"drive.files.export"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/listLabels","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listLabels)$","service_name":"google.drive","resource_name":"drive.files.listLabels"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/permissions","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/revisions","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.drive","resource_name":"drive.revisions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/teamdrives","path_regex":"^(?:/drive/v3/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v3/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/query","path_regex":"^(?:/fusiontables/v1/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sqlGet"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables","path_regex":"^(?:/fusiontables/v1/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/tasks","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.fusiontables","resource_name":"fusiontables.task.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/query","path_regex":"^(?:/fusiontables/v2/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sqlGet"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables","path_regex":"^(?:/fusiontables/v2/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/tasks","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.fusiontables","resource_name":"fusiontables.task.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/groups/v1/groups/{groupUniqueId}","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.groupssettings","resource_name":"groupsSettings.groups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/identitytoolkit/v3/relyingparty/getProjectConfig","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getProjectConfig)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getProjectConfig"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/identitytoolkit/v3/relyingparty/getRecaptchaParam","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getRecaptchaParam)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getRecaptchaParam"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/identitytoolkit/v3/relyingparty/publicKeys","path_regex":"^(?:/identitytoolkit/v3/relyingparty/publicKeys)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getPublicKeys"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/contacts","path_regex":"^(?:/mirror/v1/contacts)$","service_name":"google.mirror","resource_name":"mirror.contacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/locations","path_regex":"^(?:/mirror/v1/locations)$","service_name":"google.mirror","resource_name":"mirror.locations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/locations/{id}","path_regex":"^(?:/mirror/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.locations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/settings/{id}","path_regex":"^(?:/mirror/v1/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.settings.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/subscriptions","path_regex":"^(?:/mirror/v1/subscriptions)$","service_name":"google.mirror","resource_name":"mirror.subscriptions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline","path_regex":"^(?:/mirror/v1/timeline)$","service_name":"google.mirror","resource_name":"mirror.timeline.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline/{itemId}/attachments","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline/{itemId}/attachments/{attachmentId}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/oauth2/v1/userinfo","path_regex":"^(?:/oauth2/v1/userinfo)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/oauth2/v2/userinfo","path_regex":"^(?:/oauth2/v2/userinfo)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v1/runPagespeed","path_regex":"^(?:/pagespeedonline/v1/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v2/runPagespeed","path_regex":"^(?:/pagespeedonline/v2/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v4/runPagespeed","path_regex":"^(?:/pagespeedonline/v4/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities","path_regex":"^(?:/plus/v1/activities)$","service_name":"google.plus","resource_name":"plus.activities.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities/{activityId}","path_regex":"^(?:/plus/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.activities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities/{activityId}/comments","path_regex":"^(?:/plus/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.plus","resource_name":"plus.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities/{activityId}/people/{collection}","path_regex":"^(?:/plus/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.people.listByActivity"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/comments/{commentId}","path_regex":"^(?:/plus/v1/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people","path_regex":"^(?:/plus/v1/people)$","service_name":"google.plus","resource_name":"plus.people.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people/{userId}","path_regex":"^(?:/plus/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.people.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people/{userId}/activities/{collection}","path_regex":"^(?:/plus/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.activities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people/{userId}/people/{collection}","path_regex":"^(?:/plus/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.people.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/activities/{activityId}","path_regex":"^(?:/plusDomains/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.activities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/activities/{activityId}/comments","path_regex":"^(?:/plusDomains/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.plusDomains","resource_name":"plusDomains.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/activities/{activityId}/people/{collection}","path_regex":"^(?:/plusDomains/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.people.listByActivity"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/comments/{commentId}","path_regex":"^(?:/plusDomains/v1/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.people.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/activities/{collection}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.activities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/audiences","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences)$","service_name":"google.plusDomains","resource_name":"plusDomains.audiences.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/circles","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/circles)$","service_name":"google.plusDomains","resource_name":"plusDomains.circles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/people/{collection}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.people.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools)$","service_name":"google.replicapool","resource_name":"replicapool.pools.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.pools.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas)$","service_name":"google.replicapool","resource_name":"replicapool.replicas.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas/{replicaName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.replicas.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.zoneOperations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.zoneOperations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/instanceUpdates","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceUpdates)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.listInstanceUpdates"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/siteVerification/v1/webResource","path_regex":"^(?:/siteVerification/v1/webResource)$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b","path_regex":"^(?:/storage/v1beta1/b)$","service_name":"google.storage","resource_name":"storage.buckets.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/surveys/v2/surveys","path_regex":"^(?:/surveys/v2/surveys)$","service_name":"google.surveys","resource_name":"surveys.surveys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/surveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.surveys","resource_name":"surveys.surveys.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/surveys/v2/surveys/{surveyUrlId}/results","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.surveys","resource_name":"surveys.results.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/urlshortener/v1/url","path_regex":"^(?:/urlshortener/v1/url)$","service_name":"google.urlshortener","resource_name":"urlshortener.url.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/urlshortener/v1/url/history","path_regex":"^(?:/urlshortener/v1/url/history)$","service_name":"google.urlshortener","resource_name":"urlshortener.url.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/userinfo/v2/me","path_regex":"^(?:/userinfo/v2/me)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.v2.me.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/userinfo/v2/me","path_regex":"^(?:/userinfo/v2/me)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.v2.me.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites","path_regex":"^(?:/webmasters/v3/sites)$","service_name":"google.webmasters","resource_name":"webmasters.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps)$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/youtube/analytics/v1beta1/groupItems","path_regex":"^(?:/youtube/analytics/v1beta1/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/youtube/analytics/v1beta1/reports","path_regex":"^(?:/youtube/analytics/v1beta1/reports)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.reports.query"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.2/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.3/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/{revisionNumber}/{updateAction}","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/drives/{driveId}","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v3/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/groups/v1/groups/{groupUniqueId}","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.groupssettings","resource_name":"groupsSettings.groups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.patch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.2/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.2/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.3/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.3/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}/addDeal/{dealId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addDeal/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.addDeal"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}/removeDeal/{dealId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeDeal/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.removeDeal"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/privateauction/{privateAuctionId}/updateproposal","path_regex":"^(?:/adexchangebuyer/v1\\.4/privateauction/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateproposal)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplaceprivateauction.updateproposal"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/insert","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/insert)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals/delete","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/delete)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.delete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals/insert","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/insert)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals/update","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/update)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.update"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/notes/insert","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/insert)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacenotes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/setupcomplete","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setupcomplete)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.setupcomplete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adsensehost/v4.1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.urlchannels.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/appstate/v1/states/{stateKey}/clear","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clear)$","service_name":"google.appstate","resource_name":"appstate.states.clear"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/pages","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/approve","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approve)$","service_name":"google.blogger","resource_name":"blogger.comments.approve"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/removecontent","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removecontent)$","service_name":"google.blogger","resource_name":"blogger.comments.removeContent"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/spam","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spam)$","service_name":"google.blogger","resource_name":"blogger.comments.markAsSpam"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/publish","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.blogger","resource_name":"blogger.posts.publish"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/revert","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revert)$","service_name":"google.blogger","resource_name":"blogger.posts.revert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars","path_regex":"^(?:/calendar/v3/calendars)$","service_name":"google.calendar","resource_name":"calendar.calendars.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/acl","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.calendar","resource_name":"calendar.acl.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/acl/watch","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/watch)$","service_name":"google.calendar","resource_name":"calendar.acl.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/clear","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clear)$","service_name":"google.calendar","resource_name":"calendar.calendars.clear"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.calendar","resource_name":"calendar.events.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/import","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/import)$","service_name":"google.calendar","resource_name":"calendar.events.import"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/quickAdd","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/quickAdd)$","service_name":"google.calendar","resource_name":"calendar.events.quickAdd"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/watch","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/watch)$","service_name":"google.calendar","resource_name":"calendar.events.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}/move","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.calendar","resource_name":"calendar.events.move"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/channels/stop","path_regex":"^(?:/calendar/v3/channels/stop)$","service_name":"google.calendar","resource_name":"calendar.channels.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/freeBusy","path_regex":"^(?:/calendar/v3/freeBusy)$","service_name":"google.calendar","resource_name":"calendar.freebusy.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/users/me/calendarList","path_regex":"^(?:/calendar/v3/users/me/calendarList)$","service_name":"google.calendar","resource_name":"calendar.calendarList.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/users/me/calendarList/watch","path_regex":"^(?:/calendar/v3/users/me/calendarList/watch)$","service_name":"google.calendar","resource_name":"calendar.calendarList.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/users/me/settings/watch","path_regex":"^(?:/calendar/v3/users/me/settings/watch)$","service_name":"google.calendar","resource_name":"calendar.settings.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/consumersurveys/v2/surveys","path_regex":"^(?:/consumersurveys/v2/surveys)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/consumersurveys/v2/surveys/{resourceId}/start","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.start"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/consumersurveys/v2/surveys/{resourceId}/stop","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/orders/batch","path_regex":"^(?:/content/v2sandbox/orders/batch)$","service_name":"google.content","resource_name":"content.orders.custombatch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderinvoices/{orderId}/createChargeInvoice","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createChargeInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createchargeinvoice"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderinvoices/{orderId}/createRefundInvoice","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createRefundInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createrefundinvoice"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyAuthApproved","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyAuthApproved)$","service_name":"google.content","resource_name":"content.orderpayments.notifyauthapproved"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyAuthDeclined","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyAuthDeclined)$","service_name":"google.content","resource_name":"content.orderpayments.notifyauthdeclined"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyCharge","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyCharge)$","service_name":"google.content","resource_name":"content.orderpayments.notifycharge"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyRefund","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyRefund)$","service_name":"google.content","resource_name":"content.orderpayments.notifyrefund"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/acknowledge","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orders.acknowledge"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/cancel","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.content","resource_name":"content.orders.cancel"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/cancelLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelLineItem)$","service_name":"google.content","resource_name":"content.orders.cancellineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/inStoreRefundLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inStoreRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.instorerefundlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/refund","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refund)$","service_name":"google.content","resource_name":"content.orders.refund"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/rejectReturnLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rejectReturnLineItem)$","service_name":"google.content","resource_name":"content.orders.rejectreturnlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/returnLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnLineItem)$","service_name":"google.content","resource_name":"content.orders.returnlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/returnRefundLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.returnrefundlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/setLineItemMetadata","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLineItemMetadata)$","service_name":"google.content","resource_name":"content.orders.setlineitemmetadata"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/shipLineItems","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shipLineItems)$","service_name":"google.content","resource_name":"content.orders.shiplineitems"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/testreturn","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testreturn)$","service_name":"google.content","resource_name":"content.orders.createtestreturn"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/updateLineItemShippingDetails","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateLineItemShippingDetails)$","service_name":"google.content","resource_name":"content.orders.updatelineitemshippingdetails"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/updateMerchantOrderId","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateMerchantOrderId)$","service_name":"google.content","resource_name":"content.orders.updatemerchantorderid"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/updateShipment","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShipment)$","service_name":"google.content","resource_name":"content.orders.updateshipment"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/testorders","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders)$","service_name":"google.content","resource_name":"content.orders.createtestorder"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/testorders/{orderId}/advance","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advance)$","service_name":"google.content","resource_name":"content.orders.advancetestorder"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/testorders/{orderId}/cancelByCustomer","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelByCustomer)$","service_name":"google.content","resource_name":"content.orders.canceltestorderbycustomer"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/changes/watch","path_regex":"^(?:/drive/v2/changes/watch)$","service_name":"google.drive","resource_name":"drive.changes.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/channels/stop","path_regex":"^(?:/drive/v2/channels/stop)$","service_name":"google.drive","resource_name":"drive.channels.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/drives","path_regex":"^(?:/drive/v2/drives)$","service_name":"google.drive","resource_name":"drive.drives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/drives/{driveId}/hide","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hide)$","service_name":"google.drive","resource_name":"drive.drives.hide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/drives/{driveId}/unhide","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unhide)$","service_name":"google.drive","resource_name":"drive.drives.unhide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files","path_regex":"^(?:/drive/v2/files)$","service_name":"google.drive","resource_name":"drive.files.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/comments","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/copy","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.drive","resource_name":"drive.files.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/modifyLabels","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modifyLabels)$","service_name":"google.drive","resource_name":"drive.files.modifyLabels"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/parents","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents)$","service_name":"google.drive","resource_name":"drive.parents.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/permissions","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/properties","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties)$","service_name":"google.drive","resource_name":"drive.properties.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/touch","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/touch)$","service_name":"google.drive","resource_name":"drive.files.touch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/trash","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trash)$","service_name":"google.drive","resource_name":"drive.files.trash"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/untrash","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/untrash)$","service_name":"google.drive","resource_name":"drive.files.untrash"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/watch","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.drive","resource_name":"drive.files.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{folderId}/children","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children)$","service_name":"google.drive","resource_name":"drive.children.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/teamdrives","path_regex":"^(?:/drive/v2/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/changes/watch","path_regex":"^(?:/drive/v3/changes/watch)$","service_name":"google.drive","resource_name":"drive.changes.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/channels/stop","path_regex":"^(?:/drive/v3/channels/stop)$","service_name":"google.drive","resource_name":"drive.channels.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/drives","path_regex":"^(?:/drive/v3/drives)$","service_name":"google.drive","resource_name":"drive.drives.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/drives/{driveId}/hide","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hide)$","service_name":"google.drive","resource_name":"drive.drives.hide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/drives/{driveId}/unhide","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unhide)$","service_name":"google.drive","resource_name":"drive.drives.unhide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files","path_regex":"^(?:/drive/v3/files)$","service_name":"google.drive","resource_name":"drive.files.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/comments","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/copy","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.drive","resource_name":"drive.files.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/modifyLabels","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modifyLabels)$","service_name":"google.drive","resource_name":"drive.files.modifyLabels"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/permissions","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/watch","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.drive","resource_name":"drive.files.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/teamdrives","path_regex":"^(?:/drive/v3/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/query","path_regex":"^(?:/fusiontables/v1/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sql"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables","path_regex":"^(?:/fusiontables/v1/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/import","path_regex":"^(?:/fusiontables/v1/tables/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importTable"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/copy","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/import","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importRows"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/query","path_regex":"^(?:/fusiontables/v2/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sql"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables","path_regex":"^(?:/fusiontables/v2/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/import","path_regex":"^(?:/fusiontables/v2/tables/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importTable"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/copy","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/import","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importRows"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/refetch","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refetch)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.refetchSheet"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/replace","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replace)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.replaceRows"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/createAuthUri","path_regex":"^(?:/identitytoolkit/v3/relyingparty/createAuthUri)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.createAuthUri"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/deleteAccount","path_regex":"^(?:/identitytoolkit/v3/relyingparty/deleteAccount)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.deleteAccount"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/downloadAccount","path_regex":"^(?:/identitytoolkit/v3/relyingparty/downloadAccount)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.downloadAccount"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/emailLinkSignin","path_regex":"^(?:/identitytoolkit/v3/relyingparty/emailLinkSignin)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.emailLinkSignin"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/getAccountInfo","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getAccountInfo)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getAccountInfo"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/getOobConfirmationCode","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getOobConfirmationCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getOobConfirmationCode"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/resetPassword","path_regex":"^(?:/identitytoolkit/v3/relyingparty/resetPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.resetPassword"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/sendVerificationCode","path_regex":"^(?:/identitytoolkit/v3/relyingparty/sendVerificationCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.sendVerificationCode"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/setAccountInfo","path_regex":"^(?:/identitytoolkit/v3/relyingparty/setAccountInfo)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.setAccountInfo"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/setProjectConfig","path_regex":"^(?:/identitytoolkit/v3/relyingparty/setProjectConfig)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.setProjectConfig"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/signOutUser","path_regex":"^(?:/identitytoolkit/v3/relyingparty/signOutUser)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.signOutUser"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/signupNewUser","path_regex":"^(?:/identitytoolkit/v3/relyingparty/signupNewUser)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.signupNewUser"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/uploadAccount","path_regex":"^(?:/identitytoolkit/v3/relyingparty/uploadAccount)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.uploadAccount"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyAssertion","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyAssertion)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyAssertion"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyCustomToken","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyCustomToken)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyCustomToken"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyPassword","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyPassword"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyPhoneNumber","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyPhoneNumber)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyPhoneNumber"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/accounts/{userToken}/{accountType}/{accountName}","path_regex":"^(?:/mirror/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.accounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/contacts","path_regex":"^(?:/mirror/v1/contacts)$","service_name":"google.mirror","resource_name":"mirror.contacts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/subscriptions","path_regex":"^(?:/mirror/v1/subscriptions)$","service_name":"google.mirror","resource_name":"mirror.subscriptions.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/timeline","path_regex":"^(?:/mirror/v1/timeline)$","service_name":"google.mirror","resource_name":"mirror.timeline.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/timeline/{itemId}/attachments","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/plusDomains/v1/people/{userId}/media/{collection}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.media.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/qpxExpress/v1/trips/search","path_regex":"^(?:/qpxExpress/v1/trips/search)$","service_name":"google.qpxExpress","resource_name":"qpxExpress.trips.search"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools)$","service_name":"google.replicapool","resource_name":"replicapool.pools.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.pools.delete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas/{replicaName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.replicas.delete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas/{replicaName}/restart","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.replicapool","resource_name":"replicapool.replicas.restart"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/resize","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.replicapool","resource_name":"replicapool.pools.resize"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/updateTemplate","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateTemplate)$","service_name":"google.replicapool","resource_name":"replicapool.pools.updatetemplate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/cancel","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.cancel"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/pause","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pause)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.pause"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/resume","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.resume"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/rollback","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollback)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.rollback"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/siteVerification/v1/token","path_regex":"^(?:/siteVerification/v1/token)$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.getToken"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/siteVerification/v1/webResource","path_regex":"^(?:/siteVerification/v1/webResource)$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/getSpectrum","path_regex":"^(?:/spectrum/v1explorer/paws/getSpectrum)$","service_name":"google.spectrum","resource_name":"spectrum.paws.getSpectrum"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/getSpectrumBatch","path_regex":"^(?:/spectrum/v1explorer/paws/getSpectrumBatch)$","service_name":"google.spectrum","resource_name":"spectrum.paws.getSpectrumBatch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/init","path_regex":"^(?:/spectrum/v1explorer/paws/init)$","service_name":"google.spectrum","resource_name":"spectrum.paws.init"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/notifySpectrumUse","path_regex":"^(?:/spectrum/v1explorer/paws/notifySpectrumUse)$","service_name":"google.spectrum","resource_name":"spectrum.paws.notifySpectrumUse"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/register","path_regex":"^(?:/spectrum/v1explorer/paws/register)$","service_name":"google.spectrum","resource_name":"spectrum.paws.register"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/verifyDevice","path_regex":"^(?:/spectrum/v1explorer/paws/verifyDevice)$","service_name":"google.spectrum","resource_name":"spectrum.paws.verifyDevice"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b","path_regex":"^(?:/storage/v1beta1/b)$","service_name":"google.storage","resource_name":"storage.buckets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b/{bucket}/o","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/surveys/v2/surveys","path_regex":"^(?:/surveys/v2/surveys)$","service_name":"google.surveys","resource_name":"surveys.surveys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/surveys/v2/surveys/{resourceId}/start","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.surveys","resource_name":"surveys.surveys.start"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/surveys/v2/surveys/{resourceId}/stop","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.surveys","resource_name":"surveys.surveys.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/urlshortener/v1/url","path_regex":"^(?:/urlshortener/v1/url)$","service_name":"google.urlshortener","resource_name":"urlshortener.url.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/webmasters/v3/sites/{siteUrl}/searchAnalytics/query","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAnalytics/query)$","service_name":"google.webmasters","resource_name":"webmasters.searchanalytics.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/youtube/analytics/v1beta1/groupItems","path_regex":"^(?:/youtube/analytics/v1beta1/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.insert"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.2/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.3/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/{revisionNumber}/{updateAction}","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/appstate/v1/states/{stateKey}","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appstate","resource_name":"appstate.states.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/consumersurveys/v2/mobileAppPanels/{panelId}","path_regex":"^(?:/consumersurveys/v2/mobileAppPanels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.mobileapppanels.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/drives/{driveId}","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v2/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/groups/v1/groups/{groupUniqueId}","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.groupssettings","resource_name":"groupsSettings.groups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/mirror/v1/subscriptions/{id}","path_regex":"^(?:/mirror/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.subscriptions.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/surveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.surveys","resource_name":"surveys.surveys.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sites.add"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.submit"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.update"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveChat/bans","path_regex":"^(?:/youtube/v3/liveChat/bans)$","service_name":"google.youtube","resource_name":"youtube.liveChatBans.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveChat/messages","path_regex":"^(?:/youtube/v3/liveChat/messages)$","service_name":"google.youtube","resource_name":"youtube.liveChatMessages.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveChat/moderators","path_regex":"^(?:/youtube/v3/liveChat/moderators)$","service_name":"google.youtube","resource_name":"youtube.liveChatModerators.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/subscriptions","path_regex":"^(?:/youtube/v3/subscriptions)$","service_name":"google.youtube","resource_name":"youtube.subscriptions.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.delete"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/activities","path_regex":"^(?:/youtube/v3/activities)$","service_name":"google.youtube","resource_name":"youtube.activities.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/captions/{id}","path_regex":"^(?:/youtube/v3/captions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtube","resource_name":"youtube.captions.download"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/channels","path_regex":"^(?:/youtube/v3/channels)$","service_name":"google.youtube","resource_name":"youtube.channels.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/commentThreads","path_regex":"^(?:/youtube/v3/commentThreads)$","service_name":"google.youtube","resource_name":"youtube.commentThreads.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/i18nLanguages","path_regex":"^(?:/youtube/v3/i18nLanguages)$","service_name":"google.youtube","resource_name":"youtube.i18nLanguages.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/i18nRegions","path_regex":"^(?:/youtube/v3/i18nRegions)$","service_name":"google.youtube","resource_name":"youtube.i18nRegions.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveChat/messages","path_regex":"^(?:/youtube/v3/liveChat/messages)$","service_name":"google.youtube","resource_name":"youtube.liveChatMessages.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveChat/moderators","path_regex":"^(?:/youtube/v3/liveChat/moderators)$","service_name":"google.youtube","resource_name":"youtube.liveChatModerators.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/members","path_regex":"^(?:/youtube/v3/members)$","service_name":"google.youtube","resource_name":"youtube.members.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/membershipsLevels","path_regex":"^(?:/youtube/v3/membershipsLevels)$","service_name":"google.youtube","resource_name":"youtube.membershipsLevels.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/search","path_regex":"^(?:/youtube/v3/search)$","service_name":"google.youtube","resource_name":"youtube.search.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/subscriptions","path_regex":"^(?:/youtube/v3/subscriptions)$","service_name":"google.youtube","resource_name":"youtube.subscriptions.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/superChatEvents","path_regex":"^(?:/youtube/v3/superChatEvents)$","service_name":"google.youtube","resource_name":"youtube.superChatEvents.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videoAbuseReportReasons","path_regex":"^(?:/youtube/v3/videoAbuseReportReasons)$","service_name":"google.youtube","resource_name":"youtube.videoAbuseReportReasons.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videoCategories","path_regex":"^(?:/youtube/v3/videoCategories)$","service_name":"google.youtube","resource_name":"youtube.videoCategories.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videos/getRating","path_regex":"^(?:/youtube/v3/videos/getRating)$","service_name":"google.youtube","resource_name":"youtube.videos.getRating"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/abuseReports","path_regex":"^(?:/youtube/v3/abuseReports)$","service_name":"google.youtube","resource_name":"youtube.abuseReports.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/channelBanners/insert","path_regex":"^(?:/youtube/v3/channelBanners/insert)$","service_name":"google.youtube","resource_name":"youtube.channelBanners.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/commentThreads","path_regex":"^(?:/youtube/v3/commentThreads)$","service_name":"google.youtube","resource_name":"youtube.commentThreads.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/comments/markAsSpam","path_regex":"^(?:/youtube/v3/comments/markAsSpam)$","service_name":"google.youtube","resource_name":"youtube.comments.markAsSpam"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/comments/setModerationStatus","path_regex":"^(?:/youtube/v3/comments/setModerationStatus)$","service_name":"google.youtube","resource_name":"youtube.comments.setModerationStatus"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts/bind","path_regex":"^(?:/youtube/v3/liveBroadcasts/bind)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.bind"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts/cuepoint","path_regex":"^(?:/youtube/v3/liveBroadcasts/cuepoint)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.insertCuepoint"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts/transition","path_regex":"^(?:/youtube/v3/liveBroadcasts/transition)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.transition"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveChat/bans","path_regex":"^(?:/youtube/v3/liveChat/bans)$","service_name":"google.youtube","resource_name":"youtube.liveChatBans.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveChat/messages","path_regex":"^(?:/youtube/v3/liveChat/messages)$","service_name":"google.youtube","resource_name":"youtube.liveChatMessages.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveChat/moderators","path_regex":"^(?:/youtube/v3/liveChat/moderators)$","service_name":"google.youtube","resource_name":"youtube.liveChatModerators.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/subscriptions","path_regex":"^(?:/youtube/v3/subscriptions)$","service_name":"google.youtube","resource_name":"youtube.subscriptions.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/tests","path_regex":"^(?:/youtube/v3/tests)$","service_name":"google.youtube","resource_name":"youtube.tests.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/thumbnails/set","path_regex":"^(?:/youtube/v3/thumbnails/set)$","service_name":"google.youtube","resource_name":"youtube.thumbnails.set"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/videos/rate","path_regex":"^(?:/youtube/v3/videos/rate)$","service_name":"google.youtube","resource_name":"youtube.videos.rate"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/videos/reportAbuse","path_regex":"^(?:/youtube/v3/videos/reportAbuse)$","service_name":"google.youtube","resource_name":"youtube.videos.reportAbuse"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/watermarks/set","path_regex":"^(?:/youtube/v3/watermarks/set)$","service_name":"google.youtube","resource_name":"youtube.watermarks.set"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/watermarks/unset","path_regex":"^(?:/youtube/v3/watermarks/unset)$","service_name":"google.youtube","resource_name":"youtube.watermarks.unset"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/channels","path_regex":"^(?:/youtube/v3/channels)$","service_name":"google.youtube","resource_name":"youtube.channels.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/commentThreads","path_regex":"^(?:/youtube/v3/commentThreads)$","service_name":"google.youtube","resource_name":"youtube.youtube.v3.updateCommentThreads"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.update"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"DELETE","path_template":"/v2/groupItems","path_regex":"^(?:/v2/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.delete"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"DELETE","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.delete"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"GET","path_template":"/v2/groupItems","path_regex":"^(?:/v2/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.list"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"GET","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.list"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"GET","path_template":"/v2/reports","path_regex":"^(?:/v2/reports)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.reports.query"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"POST","path_template":"/v2/groupItems","path_regex":"^(?:/v2/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.insert"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"POST","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.insert"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"PUT","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.update"},{"hostname":"youtubereporting.googleapis.com","http_method":"DELETE","path_template":"/v1/jobs/{jobId}","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.delete"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs","path_regex":"^(?:/v1/jobs)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.list"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs/{jobId}","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.get"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs/{jobId}/reports","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.reports.list"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs/{jobId}/reports/{reportId}","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.reports.get"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.media.download"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/reportTypes","path_regex":"^(?:/v1/reportTypes)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.reportTypes.list"},{"hostname":"youtubereporting.googleapis.com","http_method":"POST","path_template":"/v1/jobs","path_regex":"^(?:/v1/jobs)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.create"}] \ No newline at end of file +[{"hostname":"","http_method":"GET","path_template":"/_ah/api/tshealth/v1/techs/count","path_regex":"^(?:/_ah/api/tshealth/v1/techs/count)$","service_name":"google.tshealth","resource_name":"tshealth.techs.count"},{"hostname":"","http_method":"GET","path_template":"/accounts/{accountId}/reports","path_regex":"^(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.repeated","resource_name":"adsense.accounts.reports.generate"},{"hostname":"","http_method":"GET","path_template":"/map","path_regex":"^(?:/map)$","service_name":"google.additionalprops","resource_name":"mapofstrings.getMap"},{"hostname":"","http_method":"GET","path_template":"/map","path_regex":"^(?:/map)$","service_name":"google.additionalprops","resource_name":"mapofstrings.getMap"},{"hostname":"","http_method":"GET","path_template":"/map","path_regex":"^(?:/map)$","service_name":"google.mapprotostruct","resource_name":"mapprotostruct.getMap"},{"hostname":"","http_method":"GET","path_template":"/reports","path_regex":"^(?:/reports)$","service_name":"google.paramrename","resource_name":"youtubeAnalytics.reports.query"},{"hostname":"","http_method":"GET","path_template":"/{project}/metricDescriptors","path_regex":"^(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors)$","service_name":"google.getwithoutbody","resource_name":"getwithoutbody.metricDescriptors.list"},{"hostname":"","http_method":"POST","path_template":"/calendars/{calendarId}/events/{eventId}/move","path_regex":"^(?:/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.paramrename","resource_name":"calendar.events.move"},{"hostname":"abusiveexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/sites/{sitesId}","path_regex":"^(?:/v1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.abusiveexperiencereport","resource_name":"abusiveexperiencereport.sites.get"},{"hostname":"abusiveexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/violatingSites","path_regex":"^(?:/v1/violatingSites)$","service_name":"google.abusiveexperiencereport","resource_name":"abusiveexperiencereport.violatingSites.list"},{"hostname":"acceleratedmobilepageurl.googleapis.com","http_method":"POST","path_template":"/v1/ampUrls:batchGet","path_regex":"^(?:/v1/ampUrls:batchGet)$","service_name":"google.acceleratedmobilepageurl","resource_name":"acceleratedmobilepageurl.ampUrls.batchGet"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.deleteAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/approvalRequests","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/serviceAccount","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.getServiceAccount"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/approvalRequests","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/serviceAccount","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.getServiceAccount"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/approvalRequests","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccount","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.getServiceAccount"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/approvalRequests","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.getAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/approvalRequests","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.list"},{"hostname":"accessapproval.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/approvalRequests/{approvalRequestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.get"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/folders/{foldersId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/accessApprovalSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalSettings)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.updateAccessApprovalSettings"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:invalidate","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::invalidate)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.invalidate"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:invalidate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::invalidate)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.invalidate"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:invalidate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::invalidate)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.invalidate"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.folders.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.organizations.approvalRequests.dismiss"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:approve","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.approve"},{"hostname":"accessapproval.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/approvalRequests/{approvalRequestsId}:dismiss","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approvalRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dismiss)$","service_name":"google.accessapproval","resource_name":"accessapproval.projects.approvalRequests.dismiss"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs/{authorizedOrgsDescsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings/{gcpUserAccessBindingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.delete"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies","path_regex":"^(?:/v1/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs/{authorizedOrgsDescsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings/{gcpUserAccessBindingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/services","path_regex":"^(?:/v1/services)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.services.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1/services/{name}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.services.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies","path_regex":"^(?:/v1beta/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.list"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"GET","path_template":"/v1beta/operations/{operationsId}","path_regex":"^(?:/v1beta/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.get"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs/{authorizedOrgsDescsId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings/{gcpUserAccessBindingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accessPolicies/{accessPoliciesId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.patch"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies","path_regex":"^(?:/v1/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels/{accessLevelsId}:testIamPermissions","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.testIamPermissions"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/accessLevels:replaceAll","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels:replaceAll)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.replaceAll"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/authorizedOrgsDescs","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedOrgsDescs)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.authorizedOrgsDescs.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters/{servicePerimetersId}:testIamPermissions","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.testIamPermissions"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters:commit","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters:commit)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.commit"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}/servicePerimeters:replaceAll","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters:replaceAll)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.replaceAll"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.getIamPolicy"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.setIamPolicy"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/accessPolicies/{accessPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.testIamPermissions"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.operations.cancel"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/gcpUserAccessBindings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gcpUserAccessBindings)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.organizations.gcpUserAccessBindings.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1beta/accessPolicies","path_regex":"^(?:/v1beta/accessPolicies)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/accessLevels","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessLevels)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.accessLevels.create"},{"hostname":"accesscontextmanager.googleapis.com","http_method":"POST","path_template":"/v1beta/accessPolicies/{accessPoliciesId}/servicePerimeters","path_regex":"^(?:/v1beta/accessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servicePerimeters)$","service_name":"google.accesscontextmanager","resource_name":"accesscontextmanager.accessPolicies.servicePerimeters.create"},{"hostname":"acmedns.googleapis.com","http_method":"GET","path_template":"/v1/acmeChallengeSets/{rootDomain}","path_regex":"^(?:/v1/acmeChallengeSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.acmedns","resource_name":"acmedns.acmeChallengeSets.get"},{"hostname":"acmedns.googleapis.com","http_method":"POST","path_template":"/v1/acmeChallengeSets/{rootDomain}:rotateChallenges","path_regex":"^(?:/v1/acmeChallengeSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rotateChallenges)$","service_name":"google.acmedns","resource_name":"acmedns.acmeChallengeSets.rotateChallenges"},{"hostname":"addressvalidation.googleapis.com","http_method":"POST","path_template":"/v1:provideValidationFeedback","path_regex":"^(?:/v1:provideValidationFeedback)$","service_name":"google.addressvalidation","resource_name":"addressvalidation.provideValidationFeedback"},{"hostname":"addressvalidation.googleapis.com","http_method":"POST","path_template":"/v1:validateAddress","path_regex":"^(?:/v1:validateAddress)$","service_name":"google.addressvalidation","resource_name":"addressvalidation.validateAddress"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.delete"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.delete"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.delete"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/invitations","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.invitations.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/invitations/{invitationId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.invitations.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/users","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.users.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/users/{userId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.users.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/creatives","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}/dealAssociations","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dealAssociations)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.dealAssociations.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/finalizedProposals","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedProposals)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.finalizedProposals.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/products","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.products.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/products/{productId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.products.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/proposals","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/publisherProfiles","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.publisherProfiles.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/accounts/{accountId}/publisherProfiles/{publisherProfileId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.publisherProfiles.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/bidMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.bidMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/bidResponseErrors","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponseErrors)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.bidResponseErrors.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/bidResponsesWithoutBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponsesWithoutBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.bidResponsesWithoutBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBidRequests","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBidRequests)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBidRequests.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/creatives","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBids.creatives.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/details","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.filteredBids.details.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/impressionMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/impressionMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.impressionMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/losingBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/losingBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.losingBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets/{filterSetsId}/nonBillableWinningBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nonBillableWinningBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.nonBillableWinningBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/bidMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.bidMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/bidResponseErrors","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponseErrors)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.bidResponseErrors.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/bidResponsesWithoutBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponsesWithoutBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.bidResponsesWithoutBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBidRequests","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBidRequests)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBidRequests.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/creatives","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBids.creatives.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/details","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.filteredBids.details.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/impressionMetrics","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/impressionMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.impressionMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/losingBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/losingBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.losingBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/bidders/{biddersId}/filterSets/{filterSetsId}/nonBillableWinningBids","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nonBillableWinningBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.nonBillableWinningBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.get"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/bidMetrics","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.bidMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/bidResponseErrors","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponseErrors)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.bidResponseErrors.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/bidResponsesWithoutBids","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bidResponsesWithoutBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.bidResponsesWithoutBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/filteredBidRequests","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBidRequests)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.filteredBidRequests.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/filteredBids","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.filteredBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/creatives","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.filteredBids.creatives.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/filteredBids/{creativeStatusId}/details","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filteredBids/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.filteredBids.details.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/impressionMetrics","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/impressionMetrics)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.impressionMetrics.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/losingBids","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/losingBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.losingBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"GET","path_template":"/v2beta1/buyers/{buyersId}/filterSets/{filterSetsId}/nonBillableWinningBids","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nonBillableWinningBids)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.nonBillableWinningBids.list"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/clients","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/invitations","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.invitations.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}/dealAssociations:add","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dealAssociations:add)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.dealAssociations.add"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}/dealAssociations:remove","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dealAssociations:remove)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.dealAssociations.remove"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}:stopWatching","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopWatching)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.stopWatching"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}:watch","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::watch)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.watch"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/finalizedProposals/{proposalId}:pause","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.finalizedProposals.pause"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/finalizedProposals/{proposalId}:resume","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.finalizedProposals.resume"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:accept","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.accept"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:addNote","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addNote)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.addNote"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:cancelNegotiation","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelNegotiation)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.cancelNegotiation"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:completeSetup","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeSetup)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.completeSetup"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:pause","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.pause"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}:resume","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.resume"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/bidders/{biddersId}/accounts/{accountsId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.accounts.filterSets.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/bidders/{biddersId}/filterSets","path_regex":"^(?:/v2beta1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.bidders.filterSets.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"POST","path_template":"/v2beta1/buyers/{buyersId}/filterSets","path_regex":"^(?:/v2beta1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filterSets)$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.buyers.filterSets.create"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.update"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/clients/{clientAccountId}/users/{userId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.clients.users.update"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/creatives/{creativeId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.creatives.update"},{"hostname":"adexchangebuyer.googleapis.com","http_method":"PUT","path_template":"/v2beta1/accounts/{accountId}/proposals/{proposalId}","path_regex":"^(?:/v2beta1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer2","resource_name":"adexchangebuyer2.accounts.proposals.update"},{"hostname":"adexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/sites/{sitesId}","path_regex":"^(?:/v1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexperiencereport","resource_name":"adexperiencereport.sites.get"},{"hostname":"adexperiencereport.googleapis.com","http_method":"GET","path_template":"/v1/violatingSites","path_regex":"^(?:/v1/violatingSites)$","service_name":"google.adexperiencereport","resource_name":"adexperiencereport.violatingSites.list"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.delete"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools/{workerpoolsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.delete"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.list"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.get"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.list"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools/{workerpoolsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.get"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.operations.get"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.patch"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools/{workerpoolsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.patch"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/instances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.create"},{"hostname":"admin-remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/instances/{instancesId}/workerpools","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerpools)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.instances.workerpools.create"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile/{resourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.mobiledevices.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/domainaliases/{domainAliasName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domainAliases.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/domains/{domainName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domains.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/roleassignments/{roleAssignmentId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roleAssignments.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers/{printServersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers/{printersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/groups/{groupKey}/aliases/{alias}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.aliases.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/aliases/{alias}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.aliases.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/asps/{codeId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/asps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.asps.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.delete"},{"hostname":"admin.googleapis.com","http_method":"DELETE","path_template":"/admin/directory/v1/users/{userKey}/tokens/{clientId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.tokens.delete"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/applications","path_regex":"^(?:/admin/datatransfer/v1/applications)$","service_name":"google.admin","resource_name":"datatransfer.applications.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/applications/{applicationId}","path_regex":"^(?:/admin/datatransfer/v1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"datatransfer.applications.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/transfers","path_regex":"^(?:/admin/datatransfer/v1/transfers)$","service_name":"google.admin","resource_name":"datatransfer.transfers.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/datatransfer/v1/transfers/{dataTransferId}","path_regex":"^(?:/admin/datatransfer/v1/transfers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"datatransfer.transfers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos)$","service_name":"google.admin","resource_name":"directory.chromeosdevices.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.chromeosdevices.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}/commands/{commandId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customer.devices.chromeos.commands.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile)$","service_name":"google.admin","resource_name":"directory.mobiledevices.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile/{resourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.mobiledevices.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/orgunits","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits)$","service_name":"google.admin","resource_name":"directory.orgunits.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/schemas","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.admin","resource_name":"directory.schemas.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domainaliases","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases)$","service_name":"google.admin","resource_name":"directory.domainAliases.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domainaliases/{domainAliasName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domainAliases.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domains","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.admin","resource_name":"directory.domains.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/domains/{domainName}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.domains.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings)$","service_name":"google.admin","resource_name":"directory.resources.buildings.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars)$","service_name":"google.admin","resource_name":"directory.resources.calendars.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/features","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features)$","service_name":"google.admin","resource_name":"directory.resources.features.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roleassignments","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments)$","service_name":"google.admin","resource_name":"directory.roleAssignments.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roleassignments/{roleAssignmentId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roleAssignments.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roles","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.admin","resource_name":"directory.roles.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roles/ALL/privileges","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/ALL/privileges)$","service_name":"google.admin","resource_name":"directory.privileges.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customerKey}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.customers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers/{printServersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers/{printersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers:listPrinterModels","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers:listPrinterModels)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.listPrinterModels"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups","path_regex":"^(?:/admin/directory/v1/groups)$","service_name":"google.admin","resource_name":"directory.groups.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/aliases","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.groups.aliases.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/hasMember/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hasMember/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.hasMember"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/members","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.admin","resource_name":"directory.members.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users","path_regex":"^(?:/admin/directory/v1/users)$","service_name":"google.admin","resource_name":"directory.users.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/aliases","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.users.aliases.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/asps","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/asps)$","service_name":"google.admin","resource_name":"directory.asps.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/asps/{codeId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/asps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.asps.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/tokens","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens)$","service_name":"google.admin","resource_name":"directory.tokens.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/tokens/{clientId}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.tokens.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/directory/v1/users/{userKey}/verificationCodes","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verificationCodes)$","service_name":"google.admin","resource_name":"directory.verificationCodes.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/activity/users/{userKey}/applications/{applicationName}","path_regex":"^(?:/admin/reports/v1/activity/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.activities.list"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/usage/dates/{date}","path_regex":"^(?:/admin/reports/v1/usage/dates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.customerUsageReports.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/usage/users/{userKey}/dates/{date}","path_regex":"^(?:/admin/reports/v1/usage/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.userUsageReport.get"},{"hostname":"admin.googleapis.com","http_method":"GET","path_template":"/admin/reports/v1/usage/{entityType}/{entityKey}/dates/{date}","path_regex":"^(?:/admin/reports/v1/usage/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"reports.entityUsageReports.get"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.chromeosdevices.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customers/{customerKey}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.customers.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers/{printServersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers/{printersId}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.patch"},{"hostname":"admin.googleapis.com","http_method":"PATCH","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.patch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/datatransfer/v1/transfers","path_regex":"^(?:/admin/datatransfer/v1/transfers)$","service_name":"google.admin","resource_name":"datatransfer.transfers.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/moveDevicesToOu","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/moveDevicesToOu)$","service_name":"google.admin","resource_name":"directory.chromeosdevices.moveDevicesToOu"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}:issueCommand","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::issueCommand)$","service_name":"google.admin","resource_name":"admin.customer.devices.chromeos.issueCommand"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{resourceId}/action","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/action)$","service_name":"google.admin","resource_name":"directory.chromeosdevices.action"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos:batchChangeStatus","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos:batchChangeStatus)$","service_name":"google.admin","resource_name":"admin.customer.devices.chromeos.batchChangeStatus"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/devices/mobile/{resourceId}/action","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/mobile/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/action)$","service_name":"google.admin","resource_name":"directory.mobiledevices.action"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/orgunits","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits)$","service_name":"google.admin","resource_name":"directory.orgunits.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customerId}/schemas","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.admin","resource_name":"directory.schemas.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/domainaliases","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainaliases)$","service_name":"google.admin","resource_name":"directory.domainAliases.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/domains","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.admin","resource_name":"directory.domains.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings)$","service_name":"google.admin","resource_name":"directory.resources.buildings.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars)$","service_name":"google.admin","resource_name":"directory.resources.calendars.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/features","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features)$","service_name":"google.admin","resource_name":"directory.resources.features.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{oldName}/rename","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rename)$","service_name":"google.admin","resource_name":"directory.resources.features.rename"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/roleassignments","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roleassignments)$","service_name":"google.admin","resource_name":"directory.roleAssignments.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customer/{customer}/roles","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.admin","resource_name":"directory.roles.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.create"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers:batchCreatePrintServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers:batchCreatePrintServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.batchCreatePrintServers"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printServers:batchDeletePrintServers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printServers:batchDeletePrintServers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printServers.batchDeletePrintServers"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.create"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers:batchCreatePrinters","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers:batchCreatePrinters)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.batchCreatePrinters"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/customers/{customersId}/chrome/printers:batchDeletePrinters","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chrome/printers:batchDeletePrinters)$","service_name":"google.admin","resource_name":"admin.customers.chrome.printers.batchDeletePrinters"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/groups","path_regex":"^(?:/admin/directory/v1/groups)$","service_name":"google.admin","resource_name":"directory.groups.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/groups/{groupKey}/aliases","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.groups.aliases.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/groups/{groupKey}/members","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.admin","resource_name":"directory.members.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users","path_regex":"^(?:/admin/directory/v1/users)$","service_name":"google.admin","resource_name":"directory.users.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/watch","path_regex":"^(?:/admin/directory/v1/users/watch)$","service_name":"google.admin","resource_name":"directory.users.watch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/aliases","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.admin","resource_name":"directory.users.aliases.insert"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/aliases/watch","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/watch)$","service_name":"google.admin","resource_name":"directory.users.aliases.watch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/makeAdmin","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/makeAdmin)$","service_name":"google.admin","resource_name":"directory.users.makeAdmin"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/signOut","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/signOut)$","service_name":"google.admin","resource_name":"directory.users.signOut"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/twoStepVerification/turnOff","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/twoStepVerification/turnOff)$","service_name":"google.admin","resource_name":"directory.twoStepVerification.turnOff"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/undelete","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/undelete)$","service_name":"google.admin","resource_name":"directory.users.undelete"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/verificationCodes/generate","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verificationCodes/generate)$","service_name":"google.admin","resource_name":"directory.verificationCodes.generate"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory/v1/users/{userKey}/verificationCodes/invalidate","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verificationCodes/invalidate)$","service_name":"google.admin","resource_name":"directory.verificationCodes.invalidate"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/directory_v1/channels/stop","path_regex":"^(?:/admin/directory_v1/channels/stop)$","service_name":"google.admin","resource_name":"admin.channels.stop"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/reports/v1/activity/users/{userKey}/applications/{applicationName}/watch","path_regex":"^(?:/admin/reports/v1/activity/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.admin","resource_name":"reports.activities.watch"},{"hostname":"admin.googleapis.com","http_method":"POST","path_template":"/admin/reports_v1/channels/stop","path_regex":"^(?:/admin/reports_v1/channels/stop)$","service_name":"google.admin","resource_name":"admin.channels.stop"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customerId}/devices/chromeos/{deviceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/chromeos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.chromeosdevices.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customerId}/orgunits/{orgunitsId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.orgunits.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customerId}/schemas/{schemaKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.schemas.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/resources/buildings/{buildingId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/buildings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.buildings.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/resources/calendars/{calendarResourceId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.calendars.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/resources/features/{featureKey}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.resources.features.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customer/{customer}/roles/{roleId}","path_regex":"^(?:/admin/directory/v1/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.roles.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/customers/{customerKey}","path_regex":"^(?:/admin/directory/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.customers.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/groups/{groupKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.groups.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/groups/{groupKey}/members/{memberKey}","path_regex":"^(?:/admin/directory/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.members.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/users/{userKey}","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admin","resource_name":"directory.users.update"},{"hostname":"admin.googleapis.com","http_method":"PUT","path_template":"/admin/directory/v1/users/{userKey}/photos/thumbnail","path_regex":"^(?:/admin/directory/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/thumbnail)$","service_name":"google.admin","resource_name":"directory.users.photos.update"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts","path_regex":"^(?:/v1/accounts)$","service_name":"google.admob","resource_name":"admob.accounts.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admob","resource_name":"admob.accounts.get"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/adUnits","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnits)$","service_name":"google.admob","resource_name":"admob.accounts.adUnits.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/apps","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.admob","resource_name":"admob.accounts.apps.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts","path_regex":"^(?:/v1beta/accounts)$","service_name":"google.admob","resource_name":"admob.accounts.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admob","resource_name":"admob.accounts.get"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/adSources","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adSources)$","service_name":"google.admob","resource_name":"admob.accounts.adSources.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/adSources/{adSourcesId}/adapters","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adapters)$","service_name":"google.admob","resource_name":"admob.accounts.adSources.adapters.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/adUnits","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnits)$","service_name":"google.admob","resource_name":"admob.accounts.adUnits.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/adUnits/{adUnitsId}/adUnitMappings","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnitMappings)$","service_name":"google.admob","resource_name":"admob.accounts.adUnits.adUnitMappings.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/apps","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.admob","resource_name":"admob.accounts.apps.list"},{"hostname":"admob.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/mediationGroups","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationGroups)$","service_name":"google.admob","resource_name":"admob.accounts.mediationGroups.list"},{"hostname":"admob.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accounts/{accountsId}/mediationGroups/{mediationGroupsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.admob","resource_name":"admob.accounts.mediationGroups.patch"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/mediationReport:generate","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.mediationReport.generate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/networkReport:generate","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.networkReport.generate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/adUnitMappings:batchCreate","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnitMappings:batchCreate)$","service_name":"google.admob","resource_name":"admob.accounts.adUnitMappings.batchCreate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/adUnits","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnits)$","service_name":"google.admob","resource_name":"admob.accounts.adUnits.create"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/adUnits/{adUnitsId}/adUnitMappings","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adUnitMappings)$","service_name":"google.admob","resource_name":"admob.accounts.adUnits.adUnitMappings.create"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/apps","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.admob","resource_name":"admob.accounts.apps.create"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/campaignReport:generate","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.campaignReport.generate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/mediationGroups","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationGroups)$","service_name":"google.admob","resource_name":"admob.accounts.mediationGroups.create"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/mediationGroups/{mediationGroupsId}/mediationAbExperiments","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationAbExperiments)$","service_name":"google.admob","resource_name":"admob.accounts.mediationGroups.mediationAbExperiments.create"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/mediationGroups/{mediationGroupsId}/mediationAbExperiments:stop","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationAbExperiments:stop)$","service_name":"google.admob","resource_name":"admob.accounts.mediationGroups.mediationAbExperiments.stop"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/mediationReport:generate","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mediationReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.mediationReport.generate"},{"hostname":"admob.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}/networkReport:generate","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkReport:generate)$","service_name":"google.admob","resource_name":"admob.accounts.networkReport.generate"},{"hostname":"adsense.googleapis.com","http_method":"DELETE","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.delete"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts","path_regex":"^(?:/v2/accounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adBlockingRecoveryTag","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adBlockingRecoveryTag)$","service_name":"google.adsense","resource_name":"adsense.accounts.getAdBlockingRecoveryTag"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adcode","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.getAdcode"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}/adcode","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.getAdcode"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}:listLinkedCustomChannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listLinkedCustomChannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.listLinkedCustomChannels"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}:listLinkedAdUnits","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listLinkedAdUnits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.listLinkedAdUnits"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/urlchannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.urlchannels.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/urlchannels/{urlchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.urlchannels.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/alerts","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/payments","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/payments)$","service_name":"google.adsense","resource_name":"adsense.accounts.payments.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/policyIssues","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyIssues)$","service_name":"google.adsense","resource_name":"adsense.accounts.policyIssues.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/policyIssues/{policyIssuesId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyIssues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.policyIssues.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/saved","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/{reportsId}/saved","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.getSaved"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/{reportsId}/saved:generate","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/saved:generate)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generate"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports/{reportsId}/saved:generateCsv","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/saved:generateCsv)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generateCsv"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports:generate","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:generate)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generate"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/reports:generateCsv","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:generateCsv)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generateCsv"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/sites","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.adsense","resource_name":"adsense.accounts.sites.list"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}/sites/{sitesId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.sites.get"},{"hostname":"adsense.googleapis.com","http_method":"GET","path_template":"/v2/accounts/{accountsId}:listChildAccounts","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listChildAccounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.listChildAccounts"},{"hostname":"adsense.googleapis.com","http_method":"PATCH","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits/{adunitsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.patch"},{"hostname":"adsense.googleapis.com","http_method":"PATCH","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels/{customchannelsId}","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.patch"},{"hostname":"adsense.googleapis.com","http_method":"POST","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/adunits","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.adunits.create"},{"hostname":"adsense.googleapis.com","http_method":"POST","path_template":"/v2/accounts/{accountsId}/adclients/{adclientsId}/customchannels","path_regex":"^(?:/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.customchannels.create"},{"hostname":"adsenseplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}/sites/{sitesId}","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.delete"},{"hostname":"adsenseplatform.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}/sites/{sitesId}","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.delete"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1/platforms/{platformsId}/accounts","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.list"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.get"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}/sites","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.list"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}/sites/{sitesId}","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.get"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1/platforms/{platformsId}/accounts:lookup","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:lookup)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.lookup"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/accounts","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.list"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.get"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}/sites","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.list"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}/sites/{sitesId}","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.get"},{"hostname":"adsenseplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/accounts:lookup","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:lookup)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.lookup"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1/platforms/{platformsId}/accounts","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.create"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}/events","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.events.create"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}/sites","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.create"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}/sites/{sitesId}:requestReview","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::requestReview)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.requestReview"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1/platforms/{platformsId}/accounts/{accountsId}:close","path_regex":"^(?:/v1/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.close"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha/platforms/{platformsId}/accounts","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.create"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}/events","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.events.create"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}/sites","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.create"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}/sites/{sitesId}:requestReview","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::requestReview)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.sites.requestReview"},{"hostname":"adsenseplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha/platforms/{platformsId}/accounts/{accountsId}:close","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.adsenseplatform","resource_name":"adsenseplatform.platforms.accounts.close"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/notifications","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifications)$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.organizations.locations.notifications.list"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/notifications/{notificationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.organizations.locations.notifications.get"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.organizations.locations.getSettings"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notifications","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifications)$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.projects.locations.notifications.list"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notifications/{notificationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.projects.locations.notifications.get"},{"hostname":"advisorynotifications.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.projects.locations.getSettings"},{"hostname":"advisorynotifications.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.organizations.locations.updateSettings"},{"hostname":"advisorynotifications.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.advisorynotifications","resource_name":"advisorynotifications.projects.locations.updateSettings"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs/{batchPredictionJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:deleteVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteVersion)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.deleteVersion"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.agents.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.apps.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs/{batchPredictionJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/cachedContents/{cachedContentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cachedContents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.cachedContents.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/edgeDevices/{edgeDevicesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeDevices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.edgeDevices.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/evaluationTasks/{evaluationTasksId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationTasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.evaluationTasks.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/exampleStores/{exampleStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exampleStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.exampleStores.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensionControllers/{extensionControllersId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensionControllers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensionControllers.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/modelMonitoringJobs/{modelMonitoringJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.modelMonitoringJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:deleteVersion","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteVersion)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.deleteVersion"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles/{ragFilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles/{ragFilesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/solvers/{solversId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/solvers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.solvers.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.delete"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs/{batchPredictionJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.restore"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:searchDataItems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchDataItems)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.searchDataItems"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}:queryDeployedModels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryDeployedModels)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.queryDeployedModels"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.listWait"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.listWait"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/featureViewSyncs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViewSyncs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.featureViewSyncs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/featureViewSyncs/{featureViewSyncsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViewSyncs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.featureViewSyncs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.listWait"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.listWait"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores:searchFeatures","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores:searchFeatures)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.searchFeatures"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}:queryArtifactLineageSubgraph","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryArtifactLineageSubgraph)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.queryArtifactLineageSubgraph"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:queryContextLineageSubgraph","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryContextLineageSubgraph)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.queryContextLineageSubgraph"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}:queryExecutionInputsAndOutputs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryExecutionInputsAndOutputs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.queryExecutionInputsAndOutputs"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/metadataSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataSchemas)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.metadataSchemas.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/metadataSchemas/{metadataSchemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.metadataSchemas.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/slices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slices)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.slices.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/slices/{slicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.slices.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:listVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listVersions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.listVersions"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nasJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}/nasTrialDetails","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasTrialDetails)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.nasTrialDetails.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}/nasTrialDetails/{nasTrialDetailsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasTrialDetails/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.nasTrialDetails.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}:read","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::read)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.read"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}:readBlobData","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readBlobData)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.readBlobData"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}:batchRead","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchRead)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.batchRead"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}:readSize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readSize)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.readSize"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}:readUsage","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readUsage)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.readUsage"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tuningJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tuningJobs/{tuningJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tuningJobs/{tuningJobsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tuningJobs/{tuningJobsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1/publishers/{publishersId}/models/{modelsId}","path_regex":"^(?:/v1/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.publishers.models.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/cacheConfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cacheConfig)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.getCacheConfig"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.agents.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.agents.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/apps/{appsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.apps.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.apps.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs/{batchPredictionJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/cachedContents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cachedContents)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.cachedContents.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/cachedContents/{cachedContentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cachedContents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.cachedContents.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}:restore","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.restore"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:searchDataItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchDataItems)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.searchDataItems"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}:queryDeployedModels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryDeployedModels)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.queryDeployedModels"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/edgeDevices/{edgeDevicesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeDevices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.edgeDevices.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/edgeDevices/{edgeDevicesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeDevices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.edgeDevices.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/evaluationTasks/{evaluationTasksId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationTasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.evaluationTasks.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/evaluationTasks/{evaluationTasksId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationTasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.evaluationTasks.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/exampleStores/{exampleStoresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exampleStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.exampleStores.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/exampleStores/{exampleStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exampleStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.exampleStores.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensionControllers/{extensionControllersId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensionControllers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensionControllers.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensionControllers/{extensionControllersId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensionControllers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensionControllers.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/featureViewSyncs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViewSyncs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.featureViewSyncs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/featureViewSyncs/{featureViewSyncsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViewSyncs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.featureViewSyncs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores:searchFeatures","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores:searchFeatures)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.searchFeatures"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}:queryArtifactLineageSubgraph","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryArtifactLineageSubgraph)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.queryArtifactLineageSubgraph"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:queryContextLineageSubgraph","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryContextLineageSubgraph)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.queryContextLineageSubgraph"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}:queryExecutionInputsAndOutputs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryExecutionInputsAndOutputs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.queryExecutionInputsAndOutputs"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/metadataSchemas","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataSchemas)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.metadataSchemas.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/metadataSchemas/{metadataSchemasId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.metadataSchemas.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/modelMonitoringJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitoringJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.modelMonitoringJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/modelMonitoringJobs/{modelMonitoringJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.modelMonitoringJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/slices","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slices)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.slices.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/slices/{slicesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.slices.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:listVersions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listVersions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.listVersions"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/nasJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}/nasTrialDetails","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasTrialDetails)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.nasTrialDetails.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}/nasTrialDetails/{nasTrialDetailsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasTrialDetails/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.nasTrialDetails.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles/{ragFilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles/{ragFilesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles/{ragFilesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/solvers/{solversId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/solvers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.solvers.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/solvers/{solversId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/solvers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.solvers.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}:read","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::read)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.read"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}:readBlobData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readBlobData)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.readBlobData"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}:batchRead","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchRead)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.batchRead"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}:readSize","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readSize)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.readSize"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}:readUsage","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readUsage)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.readUsage"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tuningJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tuningJobs/{tuningJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.get"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/publishers/{publishersId}/models","path_regex":"^(?:/v1beta1/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.aiplatform","resource_name":"aiplatform.publishers.models.list"},{"hostname":"aiplatform.googleapis.com","http_method":"GET","path_template":"/v1beta1/publishers/{publishersId}/models/{modelsId}","path_regex":"^(?:/v1beta1/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.publishers.models.get"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/cacheConfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cacheConfig)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.updateCacheConfig"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/cachedContents/{cachedContentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cachedContents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.cachedContents.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions/{datasetVersionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.patch"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs/{batchPredictionJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.export"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.import"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:computeTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.computeTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:countTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::countTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.countTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:deployModel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployModel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.deployModel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:directPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::directPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.directPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:directRawPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::directRawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.directRawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:explain","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::explain)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.explain"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:generateContent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.generateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:mutateDeployedModel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mutateDeployedModel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.mutateDeployedModel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:predict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.predict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:rawPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.rawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:serverStreamingPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.serverStreamingPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:streamGenerateContent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamGenerateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.streamGenerateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:streamRawPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamRawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.streamRawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:undeployModel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeployModel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.undeployModel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:fetchFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.fetchFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:searchNearestEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchNearestEntities)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.searchNearestEntities"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:sync","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sync)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.sync"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features:batchCreate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.batchCreate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:deleteFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.deleteFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:exportFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.exportFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:importFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.importFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:readFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.readFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:streamingReadFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamingReadFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.streamingReadFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:writeFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::writeFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.writeFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:batchReadFeatureValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchReadFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.batchReadFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:deployIndex","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployIndex)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.deployIndex"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:findNeighbors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::findNeighbors)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.findNeighbors"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:mutateDeployedIndex","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mutateDeployedIndex)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.mutateDeployedIndex"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:readIndexDatapoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readIndexDatapoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.readIndexDatapoints"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:undeployIndex","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeployIndex)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.undeployIndex"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}:removeDatapoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeDatapoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.removeDatapoints"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}:upsertDatapoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upsertDatapoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.upsertDatapoints"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts:purge)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.purge"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:addContextArtifactsAndExecutions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addContextArtifactsAndExecutions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.addContextArtifactsAndExecutions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:addContextChildren","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addContextChildren)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.addContextChildren"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:removeContextChildren","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeContextChildren)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.removeContextChildren"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts:purge)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.purge"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}:addExecutionEvents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addExecutionEvents)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.addExecutionEvents"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions:purge)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.purge"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/metadataSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataSchemas)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.metadataSchemas.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migratableResources:batchMigrate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources:batchMigrate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.batchMigrate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migratableResources:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources:search)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.search"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}:pause","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.pause"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.resume"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}:searchModelDeploymentMonitoringStatsAnomalies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchModelDeploymentMonitoringStatsAnomalies)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.searchModelDeploymentMonitoringStatsAnomalies"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/slices/{slicesId}:batchImport","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchImport)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.slices.batchImport"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations:import)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.import"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.export"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:mergeVersionAliases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mergeVersionAliases)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.mergeVersionAliases"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:updateExplanationDataset","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateExplanationDataset)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.updateExplanationDataset"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models:copy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models:copy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.copy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/models:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models:upload)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.upload"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nasJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.start"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.upgrade"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes:assign","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes:assign)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.assign"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}:reboot","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reboot)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.reboot"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs:batchCancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs:batchCancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.batchCancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelineJobs:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs:batchDelete)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.batchDelete"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:computeTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.computeTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:countTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::countTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.countTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:generateContent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.generateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:predict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.predict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:rawPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.rawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:serverStreamingPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.serverStreamingPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:streamGenerateContent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamGenerateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.streamGenerateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:streamRawPredict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamRawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.streamRawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}:pause","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.pause"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.resume"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:addTrialMeasurement","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTrialMeasurement)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.addTrialMeasurement"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:checkTrialEarlyStoppingState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkTrialEarlyStoppingState)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.checkTrialEarlyStoppingState"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:complete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.complete"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.stop"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:listOptimalTrials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:listOptimalTrials)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.listOptimalTrials"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:suggest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:suggest)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.suggest"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies:lookup)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.lookup"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}:exportTensorboardTimeSeries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportTensorboardTimeSeries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.exportTensorboardTimeSeries"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}:write","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::write)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.write"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs:batchCreate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.batchCreate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchCreate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.batchCreate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}:write","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::write)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.write"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tuningJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tuningJobs/{tuningJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tuningJobs/{tuningJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:evaluateInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateInstances)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.evaluateInstances"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.agents.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.agents.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/apps/{appsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.apps.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/apps/{appsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.apps.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/batchPredictionJobs/{batchPredictionJobsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batchPredictionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.batchPredictionJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/cachedContents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cachedContents)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.cachedContents.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customJobs/{customJobsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.customJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataLabelingJobs/{dataLabelingJobsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataLabelingJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.dataLabelingJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationSpecs/{annotationSpecsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.annotationSpecs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/annotations/{annotationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.annotations.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataItems/{dataItemsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.dataItems.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/datasetVersions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasetVersions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.datasetVersions.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/savedQueries/{savedQueriesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.savedQueries.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.export"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.datasets.import"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/deploymentResourcePools/{deploymentResourcePoolsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deploymentResourcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.deploymentResourcePools.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/edgeDevices/{edgeDevicesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeDevices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.edgeDevices.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/edgeDevices/{edgeDevicesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeDevices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.edgeDevices.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/chat/completions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chat/completions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.chat.completions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:computeTokens","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.computeTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:countTokens","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::countTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.countTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:deployModel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployModel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.deployModel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:directPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::directPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.directPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:directRawPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::directRawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.directRawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:explain","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::explain)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.explain"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:generateContent","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.generateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:mutateDeployedModel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mutateDeployedModel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.mutateDeployedModel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:predict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.predict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:rawPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.rawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:serverStreamingPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.serverStreamingPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:streamGenerateContent","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamGenerateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.streamGenerateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:streamRawPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamRawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.streamRawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:undeployModel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeployModel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.endpoints.undeployModel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/evaluationTasks/{evaluationTasksId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationTasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.evaluationTasks.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/exampleStores/{exampleStoresId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exampleStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.exampleStores.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/exampleStores/{exampleStoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exampleStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.exampleStores.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensionControllers/{extensionControllersId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensionControllers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensionControllers.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensionControllers/{extensionControllersId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensionControllers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensionControllers.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}:execute","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.execute"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions/{extensionsId}:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::query)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.query"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/extensions:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/extensions:import)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.extensions.import"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/features/{featuresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.features.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureGroups/{featureGroupsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureGroups.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:fetchFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.fetchFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:searchNearestEntities","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchNearestEntities)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.searchNearestEntities"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:streamingFetchFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamingFetchFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.streamingFetchFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:sync","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sync)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.sync"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/featureViews/{featureViewsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.featureViews.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featureOnlineStores/{featureOnlineStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featureOnlineStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featureOnlineStores.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features/{featuresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/features:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features:batchCreate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.features.batchCreate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:deleteFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.deleteFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:exportFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.exportFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:importFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.importFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:readFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.readFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:streamingReadFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamingReadFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.streamingReadFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/entityTypes/{entityTypesId}:writeFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::writeFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.entityTypes.writeFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:batchReadFeatureValues","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchReadFeatureValues)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.batchReadFeatureValues"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/featurestores/{featurestoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/featurestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.featurestores.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/hyperparameterTuningJobs/{hyperparameterTuningJobsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hyperparameterTuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.hyperparameterTuningJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:deployIndex","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployIndex)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.deployIndex"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:findNeighbors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::findNeighbors)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.findNeighbors"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:mutateDeployedIndex","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mutateDeployedIndex)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.mutateDeployedIndex"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:readIndexDatapoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readIndexDatapoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.readIndexDatapoints"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexEndpoints/{indexEndpointsId}:undeployIndex","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeployIndex)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexEndpoints.undeployIndex"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}:removeDatapoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeDatapoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.removeDatapoints"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/indexes/{indexesId}:upsertDatapoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upsertDatapoints)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.indexes.upsertDatapoints"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts/{artifactsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/artifacts:purge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts:purge)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.artifacts.purge"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:addContextArtifactsAndExecutions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addContextArtifactsAndExecutions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.addContextArtifactsAndExecutions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:addContextChildren","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addContextChildren)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.addContextChildren"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts/{contextsId}:removeContextChildren","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeContextChildren)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.removeContextChildren"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/contexts:purge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts:purge)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.contexts.purge"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions/{executionsId}:addExecutionEvents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addExecutionEvents)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.addExecutionEvents"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/executions:purge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions:purge)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.executions.purge"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/metadataSchemas","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataSchemas)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.metadataSchemas.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/metadataStores/{metadataStoresId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.metadataStores.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migratableResources/{migratableResourcesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migratableResources:batchMigrate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources:batchMigrate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.batchMigrate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migratableResources:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratableResources:search)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.migratableResources.search"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}:pause","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.pause"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.resume"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelDeploymentMonitoringJobs/{modelDeploymentMonitoringJobsId}:searchModelDeploymentMonitoringStatsAnomalies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelDeploymentMonitoringJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchModelDeploymentMonitoringStatsAnomalies)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelDeploymentMonitoringJobs.searchModelDeploymentMonitoringStatsAnomalies"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/modelMonitoringJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitoringJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.modelMonitoringJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}:searchModelMonitoringAlerts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchModelMonitoringAlerts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.searchModelMonitoringAlerts"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/modelMonitors/{modelMonitorsId}:searchModelMonitoringStats","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modelMonitors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchModelMonitoringStats)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.modelMonitors.searchModelMonitoringStats"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations/{evaluationsId}/slices/{slicesId}:batchImport","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchImport)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.slices.batchImport"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/evaluations:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations:import)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.evaluations.import"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.export"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:mergeVersionAliases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mergeVersionAliases)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.mergeVersionAliases"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models/{modelsId}:updateExplanationDataset","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateExplanationDataset)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.updateExplanationDataset"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models:copy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models:copy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.copy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/models:upload","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models:upload)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.models.upload"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/nasJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/nasJobs/{nasJobsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nasJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.nasJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}:generateAccessToken","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAccessToken)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.generateAccessToken"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookExecutionJobs/{notebookExecutionJobsId}:reportEvent","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookExecutionJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportEvent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookExecutionJobs.reportEvent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.setIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimeTemplates/{notebookRuntimeTemplatesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimeTemplates.testIamPermissions"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}:generateAccessToken","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAccessToken)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.generateAccessToken"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}:reportEvent","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportEvent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.reportEvent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}:start","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.start"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes/{notebookRuntimesId}:upgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.upgrade"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notebookRuntimes:assign","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notebookRuntimes:assign)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.notebookRuntimes.assign"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/persistentResources/{persistentResourcesId}:reboot","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/persistentResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reboot)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.persistentResources.reboot"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs/{pipelineJobsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs:batchCancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs:batchCancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.batchCancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/pipelineJobs:batchDelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelineJobs:batchDelete)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.pipelineJobs.batchDelete"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:computeTokens","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.computeTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:countTokens","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::countTokens)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.countTokens"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:generateContent","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.generateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.getIamPolicy"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:predict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.predict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:rawPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.rawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:serverStreamingPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.serverStreamingPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:streamGenerateContent","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamGenerateContent)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.streamGenerateContent"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:streamRawPredict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamRawPredict)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.publishers.models.streamRawPredict"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles/{ragFilesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles/{ragFilesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles:import)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.ragCorpora.ragFiles.import"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/ragCorpora/{ragCorporaId}/ragFiles:upload","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragCorpora/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ragFiles:upload)$","service_name":"google.aiplatform","resource_name":"aiplatform.media.upload"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reasoningEngines/{reasoningEnginesId}:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reasoningEngines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::query)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.reasoningEngines.query"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}:pause","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.pause"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.schedules.resume"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/specialistPools/{specialistPoolsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specialistPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.specialistPools.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:addTrialMeasurement","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTrialMeasurement)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.addTrialMeasurement"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:checkTrialEarlyStoppingState","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkTrialEarlyStoppingState)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.checkTrialEarlyStoppingState"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:complete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.complete"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:stop","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.stop"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:listOptimalTrials","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:listOptimalTrials)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.listOptimalTrials"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:suggest","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:suggest)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.trials.suggest"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/studies:lookup","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies:lookup)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.studies.lookup"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}/timeSeries/{timeSeriesId}:exportTensorboardTimeSeries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportTensorboardTimeSeries)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.timeSeries.exportTensorboardTimeSeries"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs/{runsId}:write","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::write)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.write"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}/runs:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs:batchCreate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.runs.batchCreate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchCreate)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.batchCreate"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/experiments/{experimentsId}:write","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::write)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.experiments.write"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tensorboards/{tensorboardsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tensorboards.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.operations.wait"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/trainingPipelines/{trainingPipelinesId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trainingPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.trainingPipelines.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tuningJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.create"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tuningJobs/{tuningJobsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tuningJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.tuningJobs.cancel"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}:evaluateInstances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateInstances)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.evaluateInstances"},{"hostname":"aiplatform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}:retrieveContexts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveContexts)$","service_name":"google.aiplatform","resource_name":"aiplatform.projects.locations.retrieveContexts"},{"hostname":"airquality.googleapis.com","http_method":"GET","path_template":"/v1/mapTypes/{mapType}/heatmapTiles/{zoom}/{x}/{y}","path_regex":"^(?:/v1/mapTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/heatmapTiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.airquality","resource_name":"airquality.mapTypes.heatmapTiles.lookupHeatmapTile"},{"hostname":"airquality.googleapis.com","http_method":"POST","path_template":"/v1/currentConditions:lookup","path_regex":"^(?:/v1/currentConditions:lookup)$","service_name":"google.airquality","resource_name":"airquality.currentConditions.lookup"},{"hostname":"airquality.googleapis.com","http_method":"POST","path_template":"/v1/forecast:lookup","path_regex":"^(?:/v1/forecast:lookup)$","service_name":"google.airquality","resource_name":"airquality.forecast.lookup"},{"hostname":"airquality.googleapis.com","http_method":"POST","path_template":"/v1/history:lookup","path_regex":"^(?:/v1/history:lookup)$","service_name":"google.airquality","resource_name":"airquality.history.lookup"},{"hostname":"alertcenter.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/alerts/{alertId}","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.delete"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts","path_regex":"^(?:/v1beta1/alerts)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.list"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts/{alertId}","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.get"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts/{alertId}/feedback","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedback)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.feedback.list"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/alerts/{alertId}/metadata","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.getMetadata"},{"hostname":"alertcenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/settings","path_regex":"^(?:/v1beta1/settings)$","service_name":"google.alertcenter","resource_name":"alertcenter.getSettings"},{"hostname":"alertcenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/settings","path_regex":"^(?:/v1beta1/settings)$","service_name":"google.alertcenter","resource_name":"alertcenter.updateSettings"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts/{alertId}/feedback","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedback)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.feedback.create"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts/{alertId}:undelete","path_regex":"^(?:/v1beta1/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.undelete"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts:batchDelete","path_regex":"^(?:/v1beta1/alerts:batchDelete)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.batchDelete"},{"hostname":"alertcenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/alerts:batchUndelete","path_regex":"^(?:/v1beta1/alerts:batchUndelete)$","service_name":"google.alertcenter","resource_name":"alertcenter.alerts.batchUndelete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.delete"},{"hostname":"alloydb.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.delete"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}/connectionInfo","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionInfo)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.getConnectionInfo"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/supportedDatabaseFlags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedDatabaseFlags)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.supportedDatabaseFlags.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}/connectionInfo","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionInfo)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.getConnectionInfo"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/supportedDatabaseFlags","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedDatabaseFlags)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.supportedDatabaseFlags.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}/connectionInfo","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionInfo)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.getConnectionInfo"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.list"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.get"},{"hostname":"alloydb.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/supportedDatabaseFlags","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedDatabaseFlags)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.supportedDatabaseFlags.list"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.patch"},{"hostname":"alloydb.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users/{usersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.patch"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:failover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failover)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.failover"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:injectFault","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::injectFault)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.injectFault"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.restart"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances:createsecondary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances:createsecondary)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.createsecondary"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:promote","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promote)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.promote"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:switchover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::switchover)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.switchover"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters:createsecondary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters:createsecondary)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.createsecondary"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters:restore)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.restore"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.cancel"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:failover","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failover)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.failover"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:injectFault","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::injectFault)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.injectFault"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:restart","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.restart"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances:createsecondary","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances:createsecondary)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.createsecondary"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:promote","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promote)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.promote"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:switchover","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::switchover)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.switchover"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters:createsecondary","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters:createsecondary)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.createsecondary"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clusters:restore","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters:restore)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.restore"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.cancel"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.backups.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:failover","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failover)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.failover"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:injectFault","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::injectFault)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.injectFault"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances/{instancesId}:restart","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.restart"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/instances:createsecondary","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances:createsecondary)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.instances.createsecondary"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/users","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.users.create"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:promote","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promote)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.promote"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:switchover","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::switchover)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.switchover"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters:createsecondary","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters:createsecondary)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.createsecondary"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/clusters:restore","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters:restore)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.clusters.restore"},{"hostname":"alloydb.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.alloydb","resource_name":"alloydb.projects.locations.operations.cancel"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports/{unsampledReportId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.delete"},{"hostname":"analytics.googleapis.com","http_method":"DELETE","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.delete"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/data/ga","path_regex":"^(?:/analytics/v3/data/ga)$","service_name":"google.analytics","resource_name":"analytics.data.ga.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/data/mcf","path_regex":"^(?:/analytics/v3/data/mcf)$","service_name":"google.analytics","resource_name":"analytics.data.mcf.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/data/realtime","path_regex":"^(?:/analytics/v3/data/realtime)$","service_name":"google.analytics","resource_name":"analytics.data.realtime.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accountSummaries","path_regex":"^(?:/analytics/v3/management/accountSummaries)$","service_name":"google.analytics","resource_name":"analytics.management.accountSummaries.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts","path_regex":"^(?:/analytics/v3/management/accounts)$","service_name":"google.analytics","resource_name":"analytics.management.accounts.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/filters","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters)$","service_name":"google.analytics","resource_name":"analytics.management.filters.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties)$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources)$","service_name":"google.analytics","resource_name":"analytics.management.customDataSources.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/uploads","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uploads)$","service_name":"google.analytics","resource_name":"analytics.management.uploads.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/uploads/{uploadId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uploads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.uploads.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions/{customDimensionId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics/{customMetricId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.analytics","resource_name":"analytics.management.profiles.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.analytics","resource_name":"analytics.management.experiments.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals)$","service_name":"google.analytics","resource_name":"analytics.management.goals.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals/{goalId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.goals.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports)$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports/{unsampledReportId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences)$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.get"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/management/segments","path_regex":"^(?:/analytics/v3/management/segments)$","service_name":"google.analytics","resource_name":"analytics.management.segments.list"},{"hostname":"analytics.googleapis.com","http_method":"GET","path_template":"/analytics/v3/metadata/{reportType}/columns","path_regex":"^(?:/analytics/v3/metadata/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.analytics","resource_name":"analytics.metadata.columns.list"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions/{customDimensionId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics/{customMetricId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals/{goalId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.goals.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.patch"},{"hostname":"analytics.googleapis.com","http_method":"PATCH","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.patch"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/filters","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters)$","service_name":"google.analytics","resource_name":"analytics.management.filters.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties)$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/deleteUploadData","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteUploadData)$","service_name":"google.analytics","resource_name":"analytics.management.uploads.deleteUploadData"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDataSources/{customDataSourceId}/uploads","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uploads)$","service_name":"google.analytics","resource_name":"analytics.management.uploads.uploadData"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.analytics","resource_name":"analytics.management.profiles.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.analytics","resource_name":"analytics.management.experiments.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals)$","service_name":"google.analytics","resource_name":"analytics.management.goals.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks)$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/unsampledReports","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unsampledReports)$","service_name":"google.analytics","resource_name":"analytics.management.unsampledReports.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences)$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.insert"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/management/clientId:hashClientId","path_regex":"^(?:/analytics/v3/management/clientId:hashClientId)$","service_name":"google.analytics","resource_name":"analytics.management.clientId.hashClientId"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/provisioning/createAccountTicket","path_regex":"^(?:/analytics/v3/provisioning/createAccountTicket)$","service_name":"google.analytics","resource_name":"analytics.provisioning.createAccountTicket"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/provisioning/createAccountTree","path_regex":"^(?:/analytics/v3/provisioning/createAccountTree)$","service_name":"google.analytics","resource_name":"analytics.provisioning.createAccountTree"},{"hostname":"analytics.googleapis.com","http_method":"POST","path_template":"/analytics/v3/userDeletion/userDeletionRequests:upsert","path_regex":"^(?:/analytics/v3/userDeletion/userDeletionRequests:upsert)$","service_name":"google.analytics","resource_name":"analytics.userDeletion.userDeletionRequest.upsert"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.accountUserLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/filters/{filterId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.filters.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customDimensions/{customDimensionId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customDimensions.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/customMetrics/{customMetricId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.customMetrics.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityAdWordsLinks/{webPropertyAdWordsLinkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityAdWordsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webPropertyAdWordsLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.webpropertyUserLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profiles.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/entityUserLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityUserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileUserLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/experiments/{experimentId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.experiments.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals/{goalId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.goals.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/profileFilterLinks/{linkId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profileFilterLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.profileFilterLinks.update"},{"hostname":"analytics.googleapis.com","http_method":"PUT","path_template":"/analytics/v3/management/accounts/{accountId}/webproperties/{webPropertyId}/remarketingAudiences/{remarketingAudienceId}","path_regex":"^(?:/analytics/v3/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analytics","resource_name":"analytics.management.remarketingAudience.update"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/accounts/{accountsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/accounts/{accountsId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/adSenseLinks/{adSenseLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adSenseLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.adSenseLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/bigQueryLinks/{bigQueryLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.bigQueryLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/calculatedMetrics/{calculatedMetricsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/calculatedMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.calculatedMetrics.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/channelGroups/{channelGroupsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventCreateRules/{eventCreateRulesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventCreateRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventCreateRules.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventEditRules/{eventEditRulesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventEditRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventEditRules.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/sKAdNetworkConversionValueSchema/{sKAdNetworkConversionValueSchemaId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sKAdNetworkConversionValueSchema/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.sKAdNetworkConversionValueSchema.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks/{displayVideo360AdvertiserLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets/{expandedDataSetsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/firebaseLinks/{firebaseLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/keyEvents/{keyEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/rollupPropertySourceLinks/{rollupPropertySourceLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollupPropertySourceLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.rollupPropertySourceLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links/{searchAds360LinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/properties/{propertiesId}/subpropertyEventFilters/{subpropertyEventFiltersId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subpropertyEventFilters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.subpropertyEventFilters.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/firebaseLinks/{firebaseLinksId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/properties/{propertiesId}/keyEvents/{keyEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.delete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accountSummaries","path_regex":"^(?:/v1alpha/accountSummaries)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accountSummaries.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts","path_regex":"^(?:/v1alpha/accounts)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/accessBindings","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchGet","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchGet)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchGet"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/dataSharingSettings","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSharingSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.getDataSharingSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties","path_regex":"^(?:/v1alpha/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/accessBindings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchGet","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchGet)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchGet"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/adSenseLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adSenseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.adSenseLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/adSenseLinks/{adSenseLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adSenseLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.adSenseLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/attributionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getAttributionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/audiences","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/audiences/{audiencesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/bigQueryLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.bigQueryLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/bigQueryLinks/{bigQueryLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.bigQueryLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/calculatedMetrics","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/calculatedMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.calculatedMetrics.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/calculatedMetrics/{calculatedMetricsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/calculatedMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.calculatedMetrics.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/channelGroups","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/channelGroups/{channelGroupsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/dataRedactionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRedactionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.getDataRedactionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/enhancedMeasurementSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enhancedMeasurementSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.getEnhancedMeasurementSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventCreateRules","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventCreateRules)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventCreateRules.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventCreateRules/{eventCreateRulesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventCreateRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventCreateRules.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventEditRules","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventEditRules)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventEditRules.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventEditRules/{eventEditRulesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventEditRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventEditRules.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/globalSiteTag","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/globalSiteTag)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.getGlobalSiteTag"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/sKAdNetworkConversionValueSchema","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sKAdNetworkConversionValueSchema)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.sKAdNetworkConversionValueSchema.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/sKAdNetworkConversionValueSchema/{sKAdNetworkConversionValueSchemaId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sKAdNetworkConversionValueSchema/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.sKAdNetworkConversionValueSchema.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks/{displayVideo360AdvertiserLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets/{expandedDataSetsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/googleSignalsSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleSignalsSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getGoogleSignalsSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/keyEvents","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/keyEvents/{keyEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/rollupPropertySourceLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollupPropertySourceLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.rollupPropertySourceLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/rollupPropertySourceLinks/{rollupPropertySourceLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollupPropertySourceLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.rollupPropertySourceLinks.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links/{searchAds360LinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/subpropertyEventFilters","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subpropertyEventFilters)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.subpropertyEventFilters.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/subpropertyEventFilters/{subpropertyEventFiltersId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subpropertyEventFilters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.subpropertyEventFilters.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties:fetchConnectedGa4Property","path_regex":"^(?:/v1alpha/properties:fetchConnectedGa4Property)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.fetchConnectedGa4Property"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accountSummaries","path_regex":"^(?:/v1beta/accountSummaries)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accountSummaries.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts","path_regex":"^(?:/v1beta/accounts)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/accounts/{accountsId}/dataSharingSettings","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSharingSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.getDataSharingSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties","path_regex":"^(?:/v1beta/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.getDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/keyEvents","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.list"},{"hostname":"analyticsadmin.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/keyEvents/{keyEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.get"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/accounts/{accountsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/accounts/{accountsId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/accessBindings/{accessBindingsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/attributionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateAttributionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/audiences/{audiencesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/bigQueryLinks/{bigQueryLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.bigQueryLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/calculatedMetrics/{calculatedMetricsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/calculatedMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.calculatedMetrics.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/channelGroups/{channelGroupsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/dataRedactionSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRedactionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.updateDataRedactionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/enhancedMeasurementSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enhancedMeasurementSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.updateEnhancedMeasurementSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventCreateRules/{eventCreateRulesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventCreateRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventCreateRules.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventEditRules/{eventEditRulesId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventEditRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventEditRules.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/sKAdNetworkConversionValueSchema/{sKAdNetworkConversionValueSchemaId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sKAdNetworkConversionValueSchema/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.sKAdNetworkConversionValueSchema.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks/{displayVideo360AdvertiserLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets/{expandedDataSetsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/googleSignalsSettings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleSignalsSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateGoogleSignalsSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/keyEvents/{keyEventsId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links/{searchAds360LinksId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/properties/{propertiesId}/subpropertyEventFilters/{subpropertyEventFiltersId}","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subpropertyEventFilters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.subpropertyEventFilters.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/accounts/{accountsId}","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/conversionEvents/{conversionEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/customDimensions/{customDimensionsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/customMetrics/{customMetricsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/dataRetentionSettings","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataRetentionSettings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.updateDataRetentionSettings"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets/{measurementProtocolSecretsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks/{googleAdsLinksId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/properties/{propertiesId}/keyEvents/{keyEventsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.patch"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchCreate","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchCreate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchCreate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchDelete","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchDelete)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchDelete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/accessBindings:batchUpdate","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchUpdate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.accessBindings.batchUpdate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}:runAccessReport","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.runAccessReport"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}:searchChangeHistoryEvents","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchChangeHistoryEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.searchChangeHistoryEvents"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts:provisionAccountTicket","path_regex":"^(?:/v1alpha/accounts:provisionAccountTicket)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.provisionAccountTicket"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties","path_regex":"^(?:/v1alpha/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchCreate","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchCreate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchCreate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchDelete","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchDelete)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchDelete"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/accessBindings:batchUpdate","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessBindings:batchUpdate)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.accessBindings.batchUpdate"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/adSenseLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adSenseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.adSenseLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/audiences","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/audiences/{audiencesId}:archive","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.audiences.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/bigQueryLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.bigQueryLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/calculatedMetrics","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/calculatedMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.calculatedMetrics.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/channelGroups","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelGroups)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.channelGroups.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customDimensions/{customDimensionsId}:archive","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/customMetrics/{customMetricsId}:archive","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventCreateRules","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventCreateRules)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventCreateRules.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventEditRules","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventEditRules)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventEditRules.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/eventEditRules:reorder","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventEditRules:reorder)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.eventEditRules.reorder"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/dataStreams/{dataStreamsId}/sKAdNetworkConversionValueSchema","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sKAdNetworkConversionValueSchema)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.sKAdNetworkConversionValueSchema.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}:approve","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.approve"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinkProposals/{displayVideo360AdvertiserLinkProposalsId}:cancel","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinkProposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinkProposals.cancel"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/displayVideo360AdvertiserLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/displayVideo360AdvertiserLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.displayVideo360AdvertiserLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/expandedDataSets","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandedDataSets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.expandedDataSets.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/keyEvents","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/rollupPropertySourceLinks","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollupPropertySourceLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.rollupPropertySourceLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/searchAds360Links","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360Links)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.searchAds360Links.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}/subpropertyEventFilters","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subpropertyEventFilters)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.subpropertyEventFilters.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}:acknowledgeUserDataCollection","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledgeUserDataCollection)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.acknowledgeUserDataCollection"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}:runAccessReport","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.runAccessReport"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:createConnectedSiteTag","path_regex":"^(?:/v1alpha/properties:createConnectedSiteTag)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.createConnectedSiteTag"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:createRollupProperty","path_regex":"^(?:/v1alpha/properties:createRollupProperty)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.createRollupProperty"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:deleteConnectedSiteTag","path_regex":"^(?:/v1alpha/properties:deleteConnectedSiteTag)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.deleteConnectedSiteTag"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:fetchAutomatedGa4ConfigurationOptOut","path_regex":"^(?:/v1alpha/properties:fetchAutomatedGa4ConfigurationOptOut)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.fetchAutomatedGa4ConfigurationOptOut"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:listConnectedSiteTags","path_regex":"^(?:/v1alpha/properties:listConnectedSiteTags)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.listConnectedSiteTags"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:provisionSubproperty","path_regex":"^(?:/v1alpha/properties:provisionSubproperty)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.provisionSubproperty"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties:setAutomatedGa4ConfigurationOptOut","path_regex":"^(?:/v1alpha/properties:setAutomatedGa4ConfigurationOptOut)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.setAutomatedGa4ConfigurationOptOut"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}:runAccessReport","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.runAccessReport"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts/{accountsId}:searchChangeHistoryEvents","path_regex":"^(?:/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchChangeHistoryEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.searchChangeHistoryEvents"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/accounts:provisionAccountTicket","path_regex":"^(?:/v1beta/accounts:provisionAccountTicket)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.accounts.provisionAccountTicket"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties","path_regex":"^(?:/v1beta/properties)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/conversionEvents","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.conversionEvents.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customDimensions","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customDimensions/{customDimensionsId}:archive","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDimensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customDimensions.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customMetrics","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/customMetrics/{customMetricsId}:archive","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.customMetrics.archive"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/dataStreams","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/dataStreams/{dataStreamsId}/measurementProtocolSecrets","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStreams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/measurementProtocolSecrets)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.dataStreams.measurementProtocolSecrets.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/firebaseLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firebaseLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.firebaseLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/googleAdsLinks","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleAdsLinks)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.googleAdsLinks.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/keyEvents","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyEvents)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.keyEvents.create"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:acknowledgeUserDataCollection","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledgeUserDataCollection)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.acknowledgeUserDataCollection"},{"hostname":"analyticsadmin.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runAccessReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAccessReport)$","service_name":"google.analyticsadmin","resource_name":"analyticsadmin.properties.runAccessReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"GET","path_template":"/v1alpha/properties/{propertiesId}/metadata","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.getMetadata"},{"hostname":"analyticsdata.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/audienceExports","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audienceExports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.audienceExports.list"},{"hostname":"analyticsdata.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/audienceExports/{audienceExportsId}","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audienceExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.audienceExports.get"},{"hostname":"analyticsdata.googleapis.com","http_method":"GET","path_template":"/v1beta/properties/{propertiesId}/metadata","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.getMetadata"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha/properties/{propertiesId}:runRealtimeReport","path_regex":"^(?:/v1alpha/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runRealtimeReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runRealtimeReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:batchRunPivotReports","path_regex":"^(?:/v1alpha:batchRunPivotReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.batchRunPivotReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:batchRunReports","path_regex":"^(?:/v1alpha:batchRunReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.batchRunReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:runPivotReport","path_regex":"^(?:/v1alpha:runPivotReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.runPivotReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1alpha:runReport","path_regex":"^(?:/v1alpha:runReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.runReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/audienceExports","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audienceExports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.audienceExports.create"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}/audienceExports/{audienceExportsId}:query","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audienceExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::query)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.audienceExports.query"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:batchRunPivotReports","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchRunPivotReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.batchRunPivotReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:batchRunReports","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchRunReports)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.batchRunReports"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:checkCompatibility","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkCompatibility)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.checkCompatibility"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runPivotReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runPivotReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runPivotReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runRealtimeReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runRealtimeReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runRealtimeReport"},{"hostname":"analyticsdata.googleapis.com","http_method":"POST","path_template":"/v1beta/properties/{propertiesId}:runReport","path_regex":"^(?:/v1beta/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runReport)$","service_name":"google.analyticsdata","resource_name":"analyticsdata.properties.runReport"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.subscriptions.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.delete"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.organizations.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.get"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.get"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:listSubscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSubscriptions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.listSubscriptions"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:listSubscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSubscriptions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listSubscriptions"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.subscriptions.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.subscriptions.get"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.organizations.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.get"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.list"},{"hostname":"analyticshub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.get"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.patch"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:subscribe","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.subscribe"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.testIamPermissions"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:subscribe","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.subscribe"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.testIamPermissions"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.subscriptions.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:refresh","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refresh)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.subscriptions.refresh"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:revoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.subscriptions.revoke"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.subscriptions.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.create"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:subscribe","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.subscribe"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}/listings/{listingsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.listings.testIamPermissions"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.getIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.setIamPolicy"},{"hostname":"analyticshub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/dataExchanges/{dataExchangesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataExchanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.analyticshub","resource_name":"analyticshub.projects.locations.dataExchanges.testIamPermissions"},{"hostname":"analyticsreporting.googleapis.com","http_method":"POST","path_template":"/v4/reports:batchGet","path_regex":"^(?:/v4/reports:batchGet)$","service_name":"google.analyticsreporting","resource_name":"analyticsreporting.reports.batchGet"},{"hostname":"analyticsreporting.googleapis.com","http_method":"POST","path_template":"/v4/userActivity:search","path_regex":"^(?:/v4/userActivity:search)$","service_name":"google.analyticsreporting","resource_name":"analyticsreporting.userActivity.search"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"DELETE","path_template":"/v1/customers/{customersId}/configurations/{configurationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.delete"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers","path_regex":"^(?:/v1/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/configurations","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/configurations/{configurationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/devices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/dpcs","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dpcs)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.dpcs.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.operations.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/customers","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.customers.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/devices/{devicesId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.get"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/vendors","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vendors)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.vendors.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/vendors/{vendorsId}/customers","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vendors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.vendors.customers.list"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"PATCH","path_template":"/v1/customers/{customersId}/configurations/{configurationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.patch"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/configurations","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.configurations.create"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/devices:applyConfiguration","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:applyConfiguration)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.applyConfiguration"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/devices:removeConfiguration","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:removeConfiguration)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.removeConfiguration"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/devices:unclaim","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:unclaim)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.customers.devices.unclaim"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/customers","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.customers.create"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices/{devicesId}/metadata","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.metadata"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:claim","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:claim)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.claim"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:claimAsync","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:claimAsync)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.claimAsync"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:findByIdentifier","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:findByIdentifier)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.findByIdentifier"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:findByOwner","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:findByOwner)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.findByOwner"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:getSimLockState","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:getSimLockState)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.getSimLockState"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:unclaim","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:unclaim)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.unclaim"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:unclaimAsync","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:unclaimAsync)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.unclaimAsync"},{"hostname":"androiddeviceprovisioning.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/devices:updateMetadataAsync","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:updateMetadataAsync)$","service_name":"google.androiddeviceprovisioning","resource_name":"androiddeviceprovisioning.partners.devices.updateMetadataAsync"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccountKeys/{keyId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccountKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.serviceaccountkeys.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters/{clusterId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/deviceAccess","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceAccess)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.revokeDeviceAccess"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs/{installId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice/{managedConfigurationForDeviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements/{entitlementId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser/{managedConfigurationForUserId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"DELETE","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps/{webAppId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.delete"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises","path_regex":"^(?:/androidenterprise/v1/enterprises)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/groupLicenses","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupLicenses)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.grouplicenses.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/groupLicenses/{groupLicenseId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupLicenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.grouplicenses.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/groupLicenses/{groupLicenseId}/users","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupLicenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.grouplicenseusers.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/appRestrictionsSchema","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appRestrictionsSchema)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.getAppRestrictionsSchema"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/managedConfigurationsSettings","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsSettings)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationssettings.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/permissions","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.getPermissions"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccount","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.getServiceAccount"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccountKeys","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccountKeys)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.serviceaccountkeys.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.getStoreLayout"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters/{clusterId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/availableProductSet","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/availableProductSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.getAvailableProductSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs/{installId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice/{managedConfigurationForDeviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/state","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/state)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.getState"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements/{entitlementId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser/{managedConfigurationForUserId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.list"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps/{webAppId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"GET","path_template":"/androidenterprise/v1/permissions/{permissionId}","path_regex":"^(?:/androidenterprise/v1/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.permissions.get"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/acknowledgeNotificationSet","path_regex":"^(?:/androidenterprise/v1/enterprises/acknowledgeNotificationSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.acknowledgeNotificationSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/completeSignup","path_regex":"^(?:/androidenterprise/v1/enterprises/completeSignup)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.completeSignup"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/enroll","path_regex":"^(?:/androidenterprise/v1/enterprises/enroll)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.enroll"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/pullNotificationSet","path_regex":"^(?:/androidenterprise/v1/enterprises/pullNotificationSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.pullNotificationSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/signupUrl","path_regex":"^(?:/androidenterprise/v1/enterprises/signupUrl)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.generateSignupUrl"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/createEnrollmentToken","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEnrollmentToken)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.createEnrollmentToken"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/createWebToken","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createWebToken)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.createWebToken"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/approve","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approve)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.approve"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/generateApprovalUrl","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generateApprovalUrl)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.generateApprovalUrl"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/products/{productId}/unapprove","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unapprove)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.products.unapprove"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/sendTestPushNotification","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendTestPushNotification)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.sendTestPushNotification"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/serviceAccountKeys","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccountKeys)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.serviceaccountkeys.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/unenroll","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unenroll)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.unenroll"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/authenticationToken","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authenticationToken)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.generateAuthenticationToken"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/forceReportUpload","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forceReportUpload)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.forceReportUpload"},{"hostname":"androidenterprise.googleapis.com","http_method":"POST","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.insert"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/account","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/account)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.setAccount"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.enterprises.setStoreLayout"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutpages.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/storeLayout/pages/{pageId}/clusters/{clusterId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeLayout/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.storelayoutclusters.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/availableProductSet","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/availableProductSet)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.users.setAvailableProductSet"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/installs/{installId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/installs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.installs.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/managedConfigurationsForDevice/{managedConfigurationForDeviceId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForDevice/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsfordevice.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/devices/{deviceId}/state","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/state)$","service_name":"google.androidenterprise","resource_name":"androidenterprise.devices.setState"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/entitlements/{entitlementId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.entitlements.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/users/{userId}/managedConfigurationsForUser/{managedConfigurationForUserId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedConfigurationsForUser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.managedconfigurationsforuser.update"},{"hostname":"androidenterprise.googleapis.com","http_method":"PUT","path_template":"/androidenterprise/v1/enterprises/{enterpriseId}/webApps/{webAppId}","path_regex":"^(?:/androidenterprise/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidenterprise","resource_name":"androidenterprise.webapps.update"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens/{enrollmentTokensId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/policies/{policiesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/enterprises/{enterprisesId}/webApps/{webAppsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.delete"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises","path_regex":"^(?:/v1/enterprises)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/applications/{applicationsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.applications.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}/operations","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.operations.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}/operations/{operationsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.operations.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens/{enrollmentTokensId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/migrationTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.migrationTokens.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/migrationTokens/{migrationTokensId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.migrationTokens.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/policies","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/policies/{policiesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/webApps","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.list"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/webApps/{webAppsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"GET","path_template":"/v1/provisioningInfo/{provisioningInfoId}","path_regex":"^(?:/v1/provisioningInfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.provisioningInfo.get"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}/policies/{policiesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.policies.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/enterprises/{enterprisesId}/webApps/{webAppsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.patch"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises","path_regex":"^(?:/v1/enterprises)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.operations.cancel"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}:issueCommand","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::issueCommand)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.devices.issueCommand"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/enrollmentTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enrollmentTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.enrollmentTokens.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/migrationTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.migrationTokens.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/webApps","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webApps.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/webTokens","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webTokens)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.enterprises.webTokens.create"},{"hostname":"androidmanagement.googleapis.com","http_method":"POST","path_template":"/v1/signupUrls","path_regex":"^(?:/v1/signupUrls)$","service_name":"google.androidmanagement","resource_name":"androidmanagement.signupUrls.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.deleteall"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.deleteall"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}/{imageId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"DELETE","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}/grants/{grantsId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.grants.delete"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{applicationsId}/externalTransactions/{externalTransactionsId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalTransactions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.externaltransactions.getexternaltransaction"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/appRecoveries","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appRecoveries)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.apprecovery.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/deviceTierConfigs","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceTierConfigs)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.applications.deviceTierConfigs.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/deviceTierConfigs/{deviceTierConfigId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceTierConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.applications.deviceTierConfigs.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.apks.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/bundles","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bundles)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.bundles.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/countryAvailability/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countryAvailability/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.countryavailability.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/details","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.details.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/testers/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.testers.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/generatedApks/{versionCode}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generatedApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.generatedapks.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/generatedApks/{versionCode}/downloads/{downloadId}:download","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generatedApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/downloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.generatedapks.download"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts:batchGet","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts:batchGet)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.batchGet"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/products/{productId}/tokens/{token}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptionsv2/tokens/{token}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptionsv2/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptionsv2.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/voidedpurchases","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/voidedpurchases)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.voidedpurchases.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/reviews","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reviews)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.reviews.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/reviews/{reviewId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.reviews.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions:batchGet","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions:batchGet)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.batchGet"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants/{variantId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.get"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants/{variantId}:download","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.download"},{"hostname":"androidpublisher.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v3/developers/{developersId}/users","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.list"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/details","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.details.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/testers/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.testers.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"PATCH","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}/grants/{grantsId}","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.grants.patch"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/internalappsharing/{packageName}/artifacts/apk","path_regex":"^(?:/androidpublisher/v3/applications/internalappsharing/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/apk)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.internalappsharingartifacts.uploadapk"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/internalappsharing/{packageName}/artifacts/bundle","path_regex":"^(?:/androidpublisher/v3/applications/internalappsharing/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/bundle)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.internalappsharingartifacts.uploadbundle"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{applicationsId}/externalTransactions","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalTransactions)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.externaltransactions.createexternaltransaction"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{applicationsId}/externalTransactions/{externalTransactionsId}:refund","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalTransactions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refund)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.externaltransactions.refundexternaltransaction"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/appRecoveries","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appRecoveries)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.apprecovery.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/appRecoveries/{appRecoveryId}:addTargeting","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appRecoveries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTargeting)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.apprecovery.addTargeting"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/appRecoveries/{appRecoveryId}:cancel","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appRecoveries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.apprecovery.cancel"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/appRecoveries/{appRecoveryId}:deploy","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appRecoveries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.apprecovery.deploy"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/dataSafety","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSafety)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.applications.dataSafety"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/deviceTierConfigs","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceTierConfigs)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.applications.deviceTierConfigs.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.insert"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.apks.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/externallyHosted","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/externallyHosted)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.apks.addexternallyhosted"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/deobfuscationFiles/{deobfuscationFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deobfuscationFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.deobfuscationfiles.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/bundles","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bundles)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.bundles.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}/{imageType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.images.upload"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}:commit","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.commit"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}:validate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.validate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.insert"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts:batchDelete","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts:batchDelete)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.batchDelete"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts:batchUpdate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts:batchUpdate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.batchUpdate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/orders/{orderId}:refund","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refund)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.orders.refund"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/pricing:convertRegionPrices","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pricing:convertRegionPrices)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.convertRegionPrices"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/products/{productId}/tokens/{token}:acknowledge","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.acknowledge"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/products/{productId}/tokens/{token}:consume","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::consume)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.consume"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:acknowledge","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.acknowledge"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:cancel","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.cancel"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:defer","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::defer)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.defer"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:refund","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refund)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.refund"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptions/{subscriptionId}/tokens/{token}:revoke","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptions.revoke"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/purchases/subscriptionsv2/tokens/{token}:revoke","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/subscriptionsv2/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.subscriptionsv2.revoke"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/reviews/{reviewId}:reply","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reply)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.reviews.reply"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}:activate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.activate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers/{offerId}:deactivate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.deactivate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers:batchGet","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers:batchGet)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.batchGet"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers:batchUpdate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers:batchUpdate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.batchUpdate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}/offers:batchUpdateStates","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers:batchUpdateStates)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.offers.batchUpdateStates"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}:activate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.activate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}:deactivate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.deactivate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans/{basePlanId}:migratePrices","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::migratePrices)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.migratePrices"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans:batchMigratePrices","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans:batchMigratePrices)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.batchMigratePrices"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}/basePlans:batchUpdateStates","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/basePlans:batchUpdateStates)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.basePlans.batchUpdateStates"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions/{productId}:archive","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.archive"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/subscriptions:batchUpdate","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions:batchUpdate)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.monetization.subscriptions.batchUpdate"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/applications/{packageName}/systemApks/{versionCode}/variants","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/systemApks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variants)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.systemapks.variants.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/developers/{developersId}/users","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.users.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"POST","path_template":"/androidpublisher/v3/developers/{developersId}/users/{usersId}/grants","path_regex":"^(?:/androidpublisher/v3/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grants)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.grants.create"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/apks/{apkVersionCode}/expansionFiles/{expansionFileType}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expansionFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.expansionfiles.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/details","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/details)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.details.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/listings/{language}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.listings.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/testers/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.testers.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/edits/{editId}/tracks/{track}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tracks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.edits.tracks.update"},{"hostname":"androidpublisher.googleapis.com","http_method":"PUT","path_template":"/androidpublisher/v3/applications/{packageName}/inappproducts/{sku}","path_regex":"^(?:/androidpublisher/v3/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inappproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inappproducts.update"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.delete"},{"hostname":"apigateway.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.delete"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.get"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.getIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.list"},{"hostname":"apigateway.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.get"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.patch"},{"hostname":"apigateway.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.patch"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.configs.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.apis.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.create"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.setIamPolicy"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.gateways.testIamPermissions"},{"hostname":"apigateway.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigateway","resource_name":"apigateway.projects.locations.operations.cancel"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/analytics/datastores/{datastoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans/{rateplansId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.keys.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}/keys/{keysId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.keys.apiproducts.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/datacollectors/{datacollectorsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.apiproducts.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/endpointAttachments/{endpointAttachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions/{debugsessionsId}/data","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.deleteData"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.undeploy"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/caches/{cachesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.caches.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/flowhooks/{flowhooksId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flowhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.flowhooks.detachSharedFlowFromFlowHook"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references/{referencesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}/{name}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.revisions.undeploy"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers/{targetserversId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides/{overridesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses/{natAddressesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/reports/{reportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.environments.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories/{apicategoriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.delete"},{"hostname":"apigee.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apidocs/{apidocsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apidocs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apidocs.delete"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/hybrid/issuers","path_regex":"^(?:/v1/hybrid/issuers)$","service_name":"google.apigee","resource_name":"apigee.hybrid.issuers.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations","path_regex":"^(?:/v1/organizations)$","service_name":"google.apigee","resource_name":"apigee.organizations.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/analytics/datastores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores)$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/analytics/datastores/{datastoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans/{rateplansId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/appgroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups)$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.keys.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.apps.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apps.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/datacollectors","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors)$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/datacollectors/{datacollectorsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/deployedIngressConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployedIngressConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.getDeployedIngressConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/balance","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/balance)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.getBalance"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/monetizationConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monetizationConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.getMonetizationConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/endpointAttachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/endpointAttachments/{endpointAttachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/deployedIngressConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployedIngressConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.getDeployedIngressConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/addonsConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addonsConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getAddonsConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/admin/schemav2","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/admin/schemav2)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.admin.getSchemav2"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/exports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/exports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.exports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/exports/{exportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/exports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.exports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apiSecurityRuntimeConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiSecurityRuntimeConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getApiSecurityRuntimeConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions/{debugsessionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions/{debugsessionsId}/data/{dataId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.data.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.getDeployments"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/debugmask","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugmask)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getDebugmask"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/deployedConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployedConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getDeployedConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/flowhooks/{flowhooksId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flowhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.flowhooks.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}/certificate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificate)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.getCertificate"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}/csr","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csr)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.csr"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/optimizedStats/{optimizedStatsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/optimizedStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.optimizedStats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries/{queriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries/{queriesId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries/{queriesId}/resulturl","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resulturl)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.getResulturl"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references/{referencesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.listEnvironmentResources"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}/{name}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityActions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityActions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityActions.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityActions/{securityActionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityActions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityActions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityActionsConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityActionsConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getSecurityActionsConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityIncidents","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityIncidents)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityIncidents.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityIncidents/{securityIncidentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityIncidents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityIncidents.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports/{securityReportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports/{securityReportsId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports/{securityReportsId}/resultView","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resultView)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.getResultView"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.revisions.getDeployments"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/stats/{statsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.stats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers/{targetserversId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getTraceConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides/{overridesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.getIamPolicy"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries/{hostQueriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries/{hostQueriesId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostQueries/{hostQueriesId}/resultView","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resultView)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.getResultView"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports/{hostSecurityReportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports/{hostSecurityReportsId}/result","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/result)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.getResult"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports/{hostSecurityReportsId}/resultView","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resultView)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.getResultView"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/hostStats/{hostStatsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.hostStats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/canaryevaluations/{canaryevaluationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/canaryevaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.canaryevaluations.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses/{natAddressesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigee","resource_name":"apigee.organizations.operations.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.operations.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/optimizedHostStats/{optimizedHostStatsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/optimizedHostStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.optimizedHostStats.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/reports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/reports/{reportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/runtimeConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.getRuntimeConfig"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityProfiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}:listRevisions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.listRevisions"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securitySettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.apigee","resource_name":"apigee.organizations.getSecuritySettings"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.deployments.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories/{apicategoriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apidocs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apidocs)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apidocs.list"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apidocs/{apidocsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apidocs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apidocs.get"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apidocs/{apidocsId}/documentation","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apidocs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentation)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apidocs.getDocumentation"},{"hostname":"apigee.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}:getProjectMapping","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getProjectMapping)$","service_name":"google.apigee","resource_name":"apigee.organizations.getProjectMapping"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/datacollectors/{datacollectorsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.modifyEnvironment"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/debugmask","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugmask)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.updateDebugmask"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityActionsConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityActionsConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.updateSecurityActionsConfig"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityIncidents/{securityIncidentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityIncidents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityIncidents.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.updateTraceConfig"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides/{overridesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/securitySettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.apigee","resource_name":"apigee.organizations.updateSecuritySettings"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories/{apicategoriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.patch"},{"hostname":"apigee.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apidocs/{apidocsId}/documentation","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apidocs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentation)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apidocs.updateDocumentation"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations","path_regex":"^(?:/v1/organizations)$","service_name":"google.apigee","resource_name":"apigee.organizations.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/analytics/datastores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores)$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/analytics/datastores:test","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores:test)$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.test"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.attributes.updateApiProductAttribute"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans)$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.revisions.updateApiProxyRevision"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/appgroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups)$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}/keys","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.keys.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.keys.updateAppGroupAppKey"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}/keys/{keysId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.keys.apiproducts.updateAppGroupAppKeyApiProduct"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/datacollectors","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacollectors)$","service_name":"google.apigee","resource_name":"apigee.organizations.datacollectors.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.setDeveloperStatus"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.generateKeyPairOrUpdateDeveloperAppStatus"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.attributes.updateDeveloperAppAttribute"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/create","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/create)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.create.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.updateDeveloperAppKey"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.apiproducts.updateDeveloperAppKeyApiProduct"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/attributes/{attributesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.attributes.updateDeveloperAttribute"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/balance:adjust","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/balance:adjust)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.balance.adjust"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/balance:credit","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/balance:credit)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.balance.credit"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/subscriptions/{subscriptionsId}:expire","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::expire)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.subscriptions.expire"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/endpointAttachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.endpointAttachments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/envgroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/envgroups/{envgroupsId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/envgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.envgroups.attachments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.updateEnvironment"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/addonsConfig:setAddonEnablement","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addonsConfig:setAddonEnablement)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.addonsConfig.setAddonEnablement"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/analytics/exports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/exports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.analytics.exports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/debugsessions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugsessions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.debugsessions.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.deploy"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments:generateDeployChangeReport","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments:generateDeployChangeReport)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.deployments.generateDeployChangeReport"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/apis/{apisId}/revisions/{revisionsId}/deployments:generateUndeployChangeReport","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments:generateUndeployChangeReport)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.apis.revisions.deployments.generateUndeployChangeReport"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments/{archiveDeploymentsId}:generateDownloadUrl","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.generateDownloadUrl"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/archiveDeployments:generateUploadUrl","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archiveDeployments:generateUploadUrl)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.archiveDeployments.generateUploadUrl"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/queries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.queries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityActions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityActions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityActions.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityActions/{securityActionsId}:disable","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityActions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityActions.disable"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityActions/{securityActionsId}:enable","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityActions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityActions.enable"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityIncidents:batchUpdate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityIncidents:batchUpdate)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityIncidents.batchUpdate"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityReports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityStats:queryTabularStats","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityStats:queryTabularStats)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityStats.queryTabularStats"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/securityStats:queryTimeSeriesStats","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityStats:queryTimeSeriesStats)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.securityStats.queryTimeSeriesStats"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}/deployments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.sharedflows.revisions.deploy"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/traceConfig/overrides","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceConfig/overrides)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.traceConfig.overrides.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.setIamPolicy"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:subscribe","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.subscribe"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.testIamPermissions"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}:unsubscribe","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribe)$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.unsubscribe"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/hostQueries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostQueries)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostQueries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/hostSecurityReports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hostSecurityReports)$","service_name":"google.apigee","resource_name":"apigee.organizations.hostSecurityReports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/attachments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.attachments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/canaryevaluations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/canaryevaluations)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.canaryevaluations.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}/natAddresses/{natAddressesId}:activate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/natAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.natAddresses.activate"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/instances/{instancesId}:reportStatus","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.apigee","resource_name":"apigee.organizations.instances.reportStatus"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps)$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/reports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityAssessmentResults:batchCompute","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityAssessmentResults:batchCompute)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityAssessmentResults.batchCompute"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityProfiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}/environments","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.environments.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityProfiles/{securityProfilesId}/environments/{environmentsId}:computeEnvironmentScores","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeEnvironmentScores)$","service_name":"google.apigee","resource_name":"apigee.organizations.securityProfiles.environments.computeEnvironmentScores"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sharedflows","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows)$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sharedflows/{sharedflowsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sharedflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sharedflows.revisions.updateSharedFlowRevision"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apicategories","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apicategories)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apicategories.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apidocs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apidocs)$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apidocs.create"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getSyncAuthorization","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getSyncAuthorization)$","service_name":"google.apigee","resource_name":"apigee.organizations.getSyncAuthorization"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setAddons","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAddons)$","service_name":"google.apigee","resource_name":"apigee.organizations.setAddons"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setSyncAuthorization","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSyncAuthorization)$","service_name":"google.apigee","resource_name":"apigee.organizations.setSyncAuthorization"},{"hostname":"apigee.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:provisionOrganization","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::provisionOrganization)$","service_name":"google.apigee","resource_name":"apigee.projects.provisionOrganization"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/analytics/datastores/{datastoresId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analytics/datastores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.analytics.datastores.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/apiproducts/{apiproductsId}/rateplans/{rateplansId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiproducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rateplans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apiproducts.rateplans.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/apis/{apisId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.apis.keyvaluemaps.entries.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/appgroups/{appgroupsId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.appgroups.apps.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/apps/{appsId}/keys/{keysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.apps.keys.replaceDeveloperAppKey"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/developers/{developersId}/monetizationConfig","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monetizationConfig)$","service_name":"google.apigee","resource_name":"apigee.organizations.developers.updateMonetizationConfig"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/flowhooks/{flowhooksId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flowhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.flowhooks.attachSharedFlowToFlowHook"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keystores/{keystoresId}/aliases/{aliasesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keystores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keystores.aliases.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.keyvaluemaps.entries.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/references/{referencesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/references/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.references.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/resourcefiles/{type}/{name}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcefiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.resourcefiles.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/environments/{environmentsId}/targetservers/{targetserversId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetservers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.environments.targetservers.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/keyvaluemaps/{keyvaluemapsId}/entries/{entriesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyvaluemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.keyvaluemaps.entries.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/reports/{reportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.reports.update"},{"hostname":"apigee.googleapis.com","http_method":"PUT","path_template":"/v1/organizations/{organizationsId}/sites/{sitesId}/apidocs/{apidocsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apidocs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigee","resource_name":"apigee.organizations.sites.apidocs.update"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.deleteRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.deleteRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.delete"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.listRevisions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.listRevisions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:getContents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getContents)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.getContents"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.documents.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.list"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.get"},{"hostname":"apigeeregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtime:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtime:getIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.runtime.getIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.patch"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.rollback"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:tagRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tagRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.tagRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.rollback"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:tagRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tagRevision)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.tagRevision"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.documents.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.documents.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.create"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.instances.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.operations.cancel"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtime:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtime:setIamPolicy)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.runtime.setIamPolicy"},{"hostname":"apigeeregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtime:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtime:testIamPermissions)$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.runtime.testIamPermissions"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/deployments/{deploymentsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.deployments.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/apis/{apisId}/versions/{versionsId}/specs/{specsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/specs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.apis.versions.specs.artifacts.replaceArtifact"},{"hostname":"apigeeregistry.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/artifacts/{artifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/artifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apigeeregistry","resource_name":"apigeeregistry.projects.locations.artifacts.replaceArtifact"},{"hostname":"apikeys.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.delete"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/keys:lookupKey","path_regex":"^(?:/v2/keys:lookupKey)$","service_name":"google.apikeys","resource_name":"apikeys.keys.lookupKey"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/operations/{operationsId}","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.operations.get"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.list"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.get"},{"hostname":"apikeys.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}/keyString","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyString)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.getKeyString"},{"hostname":"apikeys.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.patch"},{"hostname":"apikeys.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.create"},{"hostname":"apikeys.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/keys/{keysId}:undelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.apikeys","resource_name":"apikeys.projects.locations.keys.undelete"},{"hostname":"apim.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.delete"},{"hostname":"apim.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationSources/{observationSourcesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.observationSources.delete"},{"hostname":"apim.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.operations.delete"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apim","resource_name":"apim.projects.locations.list"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.get"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.list"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.get"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}/apiObservations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiObservations)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.apiObservations.list"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}/apiObservations/{apiObservationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiObservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.apiObservations.get"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}/apiObservations/{apiObservationsId}/apiOperations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiObservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiOperations)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.apiObservations.apiOperations.list"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}/apiObservations/{apiObservationsId}/apiOperations/{apiOperationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiObservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.apiObservations.apiOperations.get"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationSources","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationSources)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationSources.list"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationSources/{observationSourcesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.observationSources.get"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apim","resource_name":"apim.projects.locations.operations.list"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apim","resource_name":"apim.projects.locations.operations.get"},{"hostname":"apim.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}:listApiObservationTags","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listApiObservationTags)$","service_name":"google.apim","resource_name":"apim.projects.locations.listApiObservationTags"},{"hostname":"apim.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.create"},{"hostname":"apim.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}/apiObservations:batchEditTags","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apiObservations:batchEditTags)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.apiObservations.batchEditTags"},{"hostname":"apim.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}:disable","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.disable"},{"hostname":"apim.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationJobs/{observationJobsId}:enable","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationJobs.enable"},{"hostname":"apim.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/observationSources","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/observationSources)$","service_name":"google.apim","resource_name":"apim.projects.locations.observationSources.create"},{"hostname":"apim.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apim","resource_name":"apim.projects.locations.operations.cancel"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.delete"},{"hostname":"appengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.delete"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/authorizedDomains","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/domainMappings","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/apps/{appsId}:listRuntimes","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRuntimes)$","service_name":"google.appengine","resource_name":"appengine.apps.listRuntimes"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/authorizedDomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/authorizedDomains","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/domainMappings","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/locations","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/operations","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/authorizedDomains","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/authorizedDomains","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/domainMappings","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/locations","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/operations","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/apps/{appsId}:listRuntimes","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRuntimes)$","service_name":"google.appengine","resource_name":"appengine.apps.listRuntimes"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/authorizedDomains","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedDomains)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.applications.authorizedDomains.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.projects.locations.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/locations","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/operations","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta4/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/locations","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.appengine","resource_name":"appengine.apps.locations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/locations/{locationsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.locations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/operations","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.appengine","resource_name":"appengine.apps.operations.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.operations.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.appengine","resource_name":"appengine.apps.services.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.get"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.list"},{"hostname":"appengine.googleapis.com","http_method":"GET","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.get"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/authorizedCertificates/{authorizedCertificatesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/domainMappings/{domainMappingsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules/{ingressRulesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta4/apps/{appsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta5/apps/{appsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.patch"},{"hostname":"appengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.patch"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps","path_regex":"^(?:/v1/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/domainMappings","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/firewall/ingressRules:batchUpdate","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules:batchUpdate)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.batchUpdate"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}:repair","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.appengine","resource_name":"appengine.apps.repair"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1/apps/{appsId}:repair","path_regex":"^(?:/v1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.appengine","resource_name":"appengine.apps.repair"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/apps/{appsId}/domainMappings","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps","path_regex":"^(?:/v1beta/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/authorizedCertificates","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedCertificates)$","service_name":"google.appengine","resource_name":"appengine.apps.authorizedCertificates.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/domainMappings","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainMappings)$","service_name":"google.appengine","resource_name":"appengine.apps.domainMappings.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/firewall/ingressRules:batchUpdate","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewall/ingressRules:batchUpdate)$","service_name":"google.appengine","resource_name":"appengine.apps.firewall.ingressRules.batchUpdate"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta/apps/{appsId}:repair","path_regex":"^(?:/v1beta/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.appengine","resource_name":"appengine.apps.repair"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta4/apps","path_regex":"^(?:/v1beta4/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta4/apps/{appsId}/modules/{modulesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1beta4/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.modules.versions.instances.debug"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta5/apps","path_regex":"^(?:/v1beta5/apps)$","service_name":"google.appengine","resource_name":"appengine.apps.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.create"},{"hostname":"appengine.googleapis.com","http_method":"POST","path_template":"/v1beta5/apps/{appsId}/services/{servicesId}/versions/{versionsId}/instances/{instancesId}:debug","path_regex":"^(?:/v1beta5/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::debug)$","service_name":"google.appengine","resource_name":"appengine.apps.services.versions.instances.debug"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments/{serviceProjectAttachmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.delete"},{"hostname":"apphub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments/{serviceProjectAttachmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.delete"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.getIamPolicy"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveredServices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredServices)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredServices.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveredServices/{discoveredServicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredServices.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveredServices:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredServices:lookup)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredServices.lookup"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveredWorkloads","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredWorkloads)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredWorkloads.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveredWorkloads/{discoveredWorkloadsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredWorkloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredWorkloads.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveredWorkloads:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredWorkloads:lookup)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredWorkloads.lookup"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments/{serviceProjectAttachmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:lookupServiceProjectAttachment","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupServiceProjectAttachment)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.lookupServiceProjectAttachment"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.getIamPolicy"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredServices","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredServices)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredServices.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredServices/{discoveredServicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredServices.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredServices:findUnregistered","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredServices:findUnregistered)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredServices.findUnregistered"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredServices:lookup","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredServices:lookup)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredServices.lookup"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredWorkloads","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredWorkloads)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredWorkloads.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredWorkloads/{discoveredWorkloadsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredWorkloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredWorkloads.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredWorkloads:findUnregistered","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredWorkloads:findUnregistered)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredWorkloads.findUnregistered"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/discoveredWorkloads:lookup","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveredWorkloads:lookup)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.discoveredWorkloads.lookup"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.list"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments/{serviceProjectAttachmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.get"},{"hostname":"apphub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}:lookupServiceProjectAttachment","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupServiceProjectAttachment)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.lookupServiceProjectAttachment"},{"hostname":"apphub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.patch"},{"hostname":"apphub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.patch"},{"hostname":"apphub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.patch"},{"hostname":"apphub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.patch"},{"hostname":"apphub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.patch"},{"hostname":"apphub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.patch"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.setIamPolicy"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.testIamPermissions"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.cancel"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:detachServiceProjectAttachment","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachServiceProjectAttachment)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.detachServiceProjectAttachment"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/services","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.services.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}/workloads","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.workloads.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.setIamPolicy"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.applications.testIamPermissions"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.operations.cancel"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/serviceProjectAttachments","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceProjectAttachments)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.serviceProjectAttachments.create"},{"hostname":"apphub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}:detachServiceProjectAttachment","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachServiceProjectAttachment)$","service_name":"google.apphub","resource_name":"apphub.projects.locations.detachServiceProjectAttachment"},{"hostname":"area120tables.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/tables/{tablesId}/rows/{rowsId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.delete"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables","path_regex":"^(?:/v1alpha1/tables)$","service_name":"google.area120tables","resource_name":"area120tables.tables.list"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables/{tablesId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.get"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables/{tablesId}/rows","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.list"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/tables/{tablesId}/rows/{rowsId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.get"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/workspaces","path_regex":"^(?:/v1alpha1/workspaces)$","service_name":"google.area120tables","resource_name":"area120tables.workspaces.list"},{"hostname":"area120tables.googleapis.com","http_method":"GET","path_template":"/v1alpha1/workspaces/{workspacesId}","path_regex":"^(?:/v1alpha1/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.workspaces.get"},{"hostname":"area120tables.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/tables/{tablesId}/rows/{rowsId}","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.patch"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.create"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows:batchCreate","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows:batchCreate)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.batchCreate"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows:batchDelete","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows:batchDelete)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.batchDelete"},{"hostname":"area120tables.googleapis.com","http_method":"POST","path_template":"/v1alpha1/tables/{tablesId}/rows:batchUpdate","path_regex":"^(?:/v1alpha1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rows:batchUpdate)$","service_name":"google.area120tables","resource_name":"area120tables.tables.rows.batchUpdate"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.delete"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.operations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/dockerImages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dockerImages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.dockerImages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/dockerImages/{dockerImagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dockerImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.dockerImages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.download"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/mavenArtifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mavenArtifacts)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.mavenArtifacts.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/mavenArtifacts/{mavenArtifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mavenArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.mavenArtifacts.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/npmPackages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/npmPackages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.npmPackages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/npmPackages/{npmPackagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/npmPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.npmPackages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/pythonPackages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pythonPackages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.pythonPackages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/pythonPackages/{pythonPackagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pythonPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.pythonPackages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.getIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vpcscConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpcscConfig)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.getVpcscConfig"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.getProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.operations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.getIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.operations.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/files/{filesId}:download","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.files.download"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.list"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions/{versionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.get"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.getIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.getProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vpcscConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpcscConfig)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.updateVpcscConfig"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.updateProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags/{tagsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.patch"},{"hostname":"artifactregistry.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/projectSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectSettings)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.updateProjectSettings"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/genericArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/genericArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.genericArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/goModules:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goModules:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.goModules.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/googetArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googetArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.googetArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/googetArtifacts:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googetArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.googetArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/kfpArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/kfpArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.kfpArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/versions:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:batchDelete)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.versions.batchDelete"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:create","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.setIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.testIamPermissions"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.setIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.testIamPermissions"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:create","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/aptArtifacts:import","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aptArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.aptArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/packages/{packagesId}/tags","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.packages.tags.create"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:create","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:create)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.upload"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/yumArtifacts:import","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/yumArtifacts:import)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.yumArtifacts.import"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.setIamPolicy"},{"hostname":"artifactregistry.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.artifactregistry","resource_name":"artifactregistry.projects.locations.repositories.testIamPermissions"},{"hostname":"assuredworkloads.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.delete"},{"hostname":"assuredworkloads.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.delete"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:analyzeWorkloadMove","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeWorkloadMove)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.analyzeWorkloadMove"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.operations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.list"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.get"},{"hostname":"assuredworkloads.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:analyzeWorkloadMove","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeWorkloadMove)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.analyzeWorkloadMove"},{"hostname":"assuredworkloads.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.patch"},{"hostname":"assuredworkloads.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:mutatePartnerPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::mutatePartnerPermissions)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.mutatePartnerPermissions"},{"hostname":"assuredworkloads.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.patch"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.create"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}:acknowledge","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.acknowledge"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:enableResourceMonitoring","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableResourceMonitoring)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.enableResourceMonitoring"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:restrictAllowedResources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restrictAllowedResources)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.restrictAllowedResources"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.create"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}/violations/{violationsId}:acknowledge","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.violations.acknowledge"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:enableResourceMonitoring","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableResourceMonitoring)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.enableResourceMonitoring"},{"hostname":"assuredworkloads.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:restrictAllowedResources","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restrictAllowedResources)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.restrictAllowedResources"},{"hostname":"assuredworkloads.googleapis.com","http_method":"PUT","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/workloads/{workloadsId}:enableComplianceUpdates","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableComplianceUpdates)$","service_name":"google.assuredworkloads","resource_name":"assuredworkloads.organizations.locations.workloads.enableComplianceUpdates"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"DELETE","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.delete"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}/users/{usersId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.delete"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/auctionPackages","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.bidders.auctionPackages.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/finalizedDeals","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.bidders.finalizedDeals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/auctionPackages","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/finalizedDeals","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals/{dealsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/publisherProfiles","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.publisherProfiles.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/publisherProfiles/{publisherProfilesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.publisherProfiles.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/bidders/{biddersId}/auctionPackages","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.bidders.auctionPackages.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/bidders/{biddersId}/finalizedDeals","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.bidders.finalizedDeals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/auctionPackages","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/auctionPackages/{auctionPackagesId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/clients","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}/users","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}/users/{usersId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/dataSegments","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSegments)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.dataSegments.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/dataSegments/{dataSegmentsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSegments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.dataSegments.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/finalizedDeals","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/proposals","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}/deals","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}/deals/{dealsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/publisherProfiles","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.publisherProfiles.list"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"GET","path_template":"/v1alpha/buyers/{buyersId}/publisherProfiles/{publisherProfilesId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.publisherProfiles.get"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals/{dealsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/buyers/{buyersId}/dataSegments/{dataSegmentsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSegments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.dataSegments.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}/deals/{dealsId}","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.patch"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:subscribe","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.subscribe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:subscribeClients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribeClients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.subscribeClients"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:unsubscribe","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.unsubscribe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:unsubscribeClients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribeClients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.unsubscribeClients"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.create"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.create"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}:activate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.activate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}/users/{usersId}:deactivate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.deactivate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}:activate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.activate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/clients/{clientsId}:deactivate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.deactivate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:addCreative","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addCreative)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.addCreative"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:pause","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.pause"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:resume","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.resume"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:setReadyToServe","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setReadyToServe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.setReadyToServe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}/deals:batchUpdate","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals:batchUpdate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.batchUpdate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}:accept","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.accept"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}:addNote","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addNote)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.addNote"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals/{proposalsId}:cancelNegotiation","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelNegotiation)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.cancelNegotiation"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/proposals:sendRfp","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals:sendRfp)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.sendRfp"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:subscribe","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.subscribe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:subscribeClients","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::subscribeClients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.subscribeClients"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:unsubscribe","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.unsubscribe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/auctionPackages/{auctionPackagesId}:unsubscribeClients","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/auctionPackages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unsubscribeClients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.auctionPackages.unsubscribeClients"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/clients","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.create"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}/users","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.create"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}/users/{usersId}:activate","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.activate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}/users/{usersId}:deactivate","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.users.deactivate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}:activate","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.activate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/clients/{clientsId}:deactivate","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.clients.deactivate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/dataSegments","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSegments)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.dataSegments.create"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/dataSegments/{dataSegmentsId}:activate","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSegments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.dataSegments.activate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/dataSegments/{dataSegmentsId}:deactivate","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSegments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.dataSegments.deactivate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:addCreative","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addCreative)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.addCreative"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:pause","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.pause"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:resume","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.resume"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/finalizedDeals/{finalizedDealsId}:setReadyToServe","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/finalizedDeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setReadyToServe)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.finalizedDeals.setReadyToServe"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}/deals:batchUpdate","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals:batchUpdate)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.deals.batchUpdate"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}:accept","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.accept"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}:addNote","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addNote)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.addNote"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/proposals/{proposalsId}:cancelNegotiation","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelNegotiation)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.cancelNegotiation"},{"hostname":"authorizedbuyersmarketplace.googleapis.com","http_method":"POST","path_template":"/v1alpha/buyers/{buyersId}/proposals:sendRfp","path_regex":"^(?:/v1alpha/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proposals:sendRfp)$","service_name":"google.authorizedbuyersmarketplace","resource_name":"authorizedbuyersmarketplace.buyers.proposals.sendRfp"},{"hostname":"backupdr.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlanAssociations/{backupPlanAssociationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlanAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlanAssociations.delete"},{"hostname":"backupdr.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlans.delete"},{"hostname":"backupdr.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.delete"},{"hostname":"backupdr.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.backups.delete"},{"hostname":"backupdr.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/managementServers/{managementServersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.managementServers.delete"},{"hostname":"backupdr.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.operations.delete"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.get"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlanAssociations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlanAssociations)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlanAssociations.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlanAssociations/{backupPlanAssociationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlanAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlanAssociations.get"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlans.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlans.get"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.get"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.get"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.backups.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.backups.get"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults:fetchUsable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults:fetchUsable)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.fetchUsable"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/managementServers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementServers)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.managementServers.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/managementServers/{managementServersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.managementServers.get"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/managementServers/{managementServersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.managementServers.getIamPolicy"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.operations.list"},{"hostname":"backupdr.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.operations.get"},{"hostname":"backupdr.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.patch"},{"hostname":"backupdr.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.patch"},{"hostname":"backupdr.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.backups.patch"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlanAssociations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlanAssociations)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlanAssociations.create"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlanAssociations/{backupPlanAssociationsId}:triggerBackup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlanAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::triggerBackup)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlanAssociations.triggerBackup"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupPlans.create"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.create"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}/backups/{backupsId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.backups.restore"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}:abandonBackup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::abandonBackup)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.abandonBackup"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}:fetchAccessToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchAccessToken)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.fetchAccessToken"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}:finalizeBackup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::finalizeBackup)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.finalizeBackup"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}:initiateBackup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initiateBackup)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.initiateBackup"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}:remove","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::remove)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.remove"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}/dataSources/{dataSourcesId}:setInternalStatus","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setInternalStatus)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.dataSources.setInternalStatus"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupVaults/{backupVaultsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupVaults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.backupVaults.testIamPermissions"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/managementServers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementServers)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.managementServers.create"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/managementServers/{managementServersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.managementServers.setIamPolicy"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/managementServers/{managementServersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.managementServers.testIamPermissions"},{"hostname":"backupdr.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.backupdr","resource_name":"backupdr.projects.locations.operations.cancel"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/sshKeys/{sshKeysId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.sshKeys.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.delete"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/provisioningQuotas","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningQuotas)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.provisioningQuotas.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:loadAuthInfo","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::loadAuthInfo)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.loadAuthInfo"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks/{networksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks:listNetworkUsage","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks:listNetworkUsage)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.listNetworkUsage"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.operations.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/osImages","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osImages)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.osImages.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/osImages/{osImagesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.osImages.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs/{provisioningConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningQuotas","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningQuotas)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningQuotas.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/sshKeys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshKeys)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.sshKeys.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/luns","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/luns)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.luns.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/luns/{lunsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/luns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.luns.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.list"},{"hostname":"baremetalsolution.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.get"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks/{networksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs/{provisioningConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.patch"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.operations.cancel"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}:submitProvisioningConfig","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::submitProvisioningConfig)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.submitProvisioningConfig"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:detachLun","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachLun)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.detachLun"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:disableHyperthreading","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableHyperthreading)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.disableHyperthreading"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:disableInteractiveSerialConsole","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableInteractiveSerialConsole)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.disableInteractiveSerialConsole"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:enableHyperthreading","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableHyperthreading)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.enableHyperthreading"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:enableInteractiveSerialConsole","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableInteractiveSerialConsole)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.enableInteractiveSerialConsole"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reimage","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reimage)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.reimage"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reset","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.reset"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:start","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.start"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:stop","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.instances.stop"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/networks/{networksId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.networks.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nfsShares/{nfsSharesId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nfsShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.nfsShares.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/provisioningConfigs:submit","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/provisioningConfigs:submit)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.provisioningConfigs.submit"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/sshKeys","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshKeys)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.sshKeys.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/luns/{lunsId}:evict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/luns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evict)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.luns.evict"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.create"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}/snapshots/{snapshotsId}:restoreVolumeSnapshot","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restoreVolumeSnapshot)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.snapshots.restoreVolumeSnapshot"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}:evict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evict)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.evict"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}:rename","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.rename"},{"hostname":"baremetalsolution.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/volumes/{volumesId}:resize","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resize)$","service_name":"google.baremetalsolution","resource_name":"baremetalsolution.projects.locations.volumes.resize"},{"hostname":"batch.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.delete"},{"hostname":"batch.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.delete"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.batch","resource_name":"batch.projects.locations.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.get"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.get"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/taskGroups/{taskGroupsId}/tasks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taskGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.taskGroups.tasks.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/taskGroups/{taskGroupsId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taskGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.taskGroups.tasks.get"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.list"},{"hostname":"batch.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.get"},{"hostname":"batch.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.batch","resource_name":"batch.projects.locations.jobs.create"},{"hostname":"batch.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.batch","resource_name":"batch.projects.locations.operations.cancel"},{"hostname":"batch.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/state:report","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/state:report)$","service_name":"google.batch","resource_name":"batch.projects.locations.state.report"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways/{securityGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.delete"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections:resolve)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.resolve"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:resolveInstanceConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolveInstanceConfig)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.resolveInstanceConfig"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:shouldThrottle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::shouldThrottle)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.shouldThrottle"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}:getIamPolicy","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}:getIamPolicy","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}:getIamPolicy","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/insights","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.insights.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/insights/{insightsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.insights.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/insights/{insightsId}:configuredInsight","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configuredInsight)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.insights.configuredInsight"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:cancel","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.cancel"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:restart","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.restart"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections:resolve)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.resolve"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:resolveInstanceConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolveInstanceConfig)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.resolveInstanceConfig"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:shouldThrottle","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::shouldThrottle)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.shouldThrottle"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applicationDomains/{applicationDomainsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applicationDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applicationDomains.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applications.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections:resolve)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.resolve"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:resolveInstanceConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolveInstanceConfig)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.resolveInstanceConfig"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/insights","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.insights.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/insights/{insightsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.insights.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/insights/{insightsId}:configuredInsight","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configuredInsight)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.insights.configuredInsight"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/netConnections/{netConnectionsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/netConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.netConnections.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.list"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways/{securityGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.get"},{"hostname":"beyondcorp.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways/{securityGatewaysId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.getIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways/{securityGatewaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.patch"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.cancel"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:reportStatus","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.reportStatus"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.cancel"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}:setIamPolicy","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/browserDlpRules/{browserDlpRulesId}:testIamPermissions","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browserDlpRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.browserDlpRules.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}:setIamPolicy","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}/proxyConfigs/{proxyConfigsId}:testIamPermissions","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/proxyConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.proxyConfigs.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}:setIamPolicy","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/global/partnerTenants/{partnerTenantsId}:testIamPermissions","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/partnerTenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.global.partnerTenants.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.operations.cancel"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.organizations.locations.subscriptions.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnections/{appConnectionsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:reportStatus","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.reportStatus"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appConnectors/{appConnectorsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appConnectors.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appGateways/{appGatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.appGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applicationDomains/{applicationDomainsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applicationDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applicationDomains.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applicationDomains/{applicationDomainsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applicationDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applicationDomains.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applications.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/applications/{applicationsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.applications.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientConnectorServices/{clientConnectorServicesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientConnectorServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientConnectorServices.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/clientGateways/{clientGatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.clientGateways.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:reportStatus","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportStatus)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.reportStatus"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.connectors.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/netConnections/{netConnectionsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/netConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.netConnections.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/netConnections/{netConnectionsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/netConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.netConnections.testIamPermissions"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.operations.cancel"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.create"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways/{securityGatewaysId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.setIamPolicy"},{"hostname":"beyondcorp.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/securityGateways/{securityGatewaysId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.beyondcorp","resource_name":"beyondcorp.projects.locations.securityGateways.testIamPermissions"},{"hostname":"biglake.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.delete"},{"hostname":"biglake.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.delete"},{"hostname":"biglake.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}/tables/{tablesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.tables.delete"},{"hostname":"biglake.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.list"},{"hostname":"biglake.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.get"},{"hostname":"biglake.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.list"},{"hostname":"biglake.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.get"},{"hostname":"biglake.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}/tables","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.tables.list"},{"hostname":"biglake.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}/tables/{tablesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.tables.get"},{"hostname":"biglake.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.patch"},{"hostname":"biglake.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}/tables/{tablesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.tables.patch"},{"hostname":"biglake.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.create"},{"hostname":"biglake.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.create"},{"hostname":"biglake.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}/tables","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.tables.create"},{"hostname":"biglake.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/databases/{databasesId}/tables/{tablesId}:rename","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.biglake","resource_name":"biglake.projects.locations.catalogs.databases.tables.rename"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models/{modelsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.models.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.routines.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.delete"},{"hostname":"bigquery.googleapis.com","http_method":"DELETE","path_template":"/bigquery/v2/projects/{projectsId}/jobs/{jobsId}/delete","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/delete)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.delete"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects","path_regex":"^(?:/bigquery/v2/projects)$","service_name":"google.bigquery","resource_name":"bigquery.projects.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.bigquery","resource_name":"bigquery.datasets.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.bigquery","resource_name":"bigquery.models.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models/{modelsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.models.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines)$","service_name":"google.bigquery","resource_name":"bigquery.routines.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.routines.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigquery","resource_name":"bigquery.tables.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/data","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data)$","service_name":"google.bigquery","resource_name":"bigquery.tabledata.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/rowAccessPolicies","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rowAccessPolicies)$","service_name":"google.bigquery","resource_name":"bigquery.rowAccessPolicies.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/jobs","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.list"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.jobs.get"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/queries/{queriesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.jobs.getQueryResults"},{"hostname":"bigquery.googleapis.com","http_method":"GET","path_template":"/bigquery/v2/projects/{projectsId}/serviceAccount","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.bigquery","resource_name":"bigquery.projects.getServiceAccount"},{"hostname":"bigquery.googleapis.com","http_method":"PATCH","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.patch"},{"hostname":"bigquery.googleapis.com","http_method":"PATCH","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/models/{modelsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.models.patch"},{"hostname":"bigquery.googleapis.com","http_method":"PATCH","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.patch"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.bigquery","resource_name":"bigquery.datasets.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines)$","service_name":"google.bigquery","resource_name":"bigquery.routines.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}:getIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.routines.getIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}:setIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.routines.setIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigquery","resource_name":"bigquery.tables.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/insertAll","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertAll)$","service_name":"google.bigquery","resource_name":"bigquery.tabledata.insertAll"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/rowAccessPolicies/{rowAccessPoliciesId}:getIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rowAccessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.rowAccessPolicies.getIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}/rowAccessPolicies/{rowAccessPoliciesId}:testIamPermissions","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rowAccessPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigquery","resource_name":"bigquery.rowAccessPolicies.testIamPermissions"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.tables.getIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigquery","resource_name":"bigquery.tables.setIamPolicy"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigquery","resource_name":"bigquery.tables.testIamPermissions"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}:undelete","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.bigquery","resource_name":"bigquery.datasets.undelete"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/jobs","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.insert"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/jobs/{jobsId}/cancel","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.cancel"},{"hostname":"bigquery.googleapis.com","http_method":"POST","path_template":"/bigquery/v2/projects/{projectsId}/queries","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queries)$","service_name":"google.bigquery","resource_name":"bigquery.jobs.query"},{"hostname":"bigquery.googleapis.com","http_method":"PUT","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.datasets.update"},{"hostname":"bigquery.googleapis.com","http_method":"PUT","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/routines/{routinesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.routines.update"},{"hostname":"bigquery.googleapis.com","http_method":"PUT","path_template":"/bigquery/v2/projects/{projectsId}/datasets/{datasetsId}/tables/{tablesId}","path_regex":"^(?:/bigquery/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquery","resource_name":"bigquery.tables.update"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.delete"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.delete"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.list"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.get"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.list"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.get"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.patch"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.patch"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/credential","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credential)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.updateCredential"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.create"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.getIamPolicy"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.setIamPolicy"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.testIamPermissions"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.create"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.getIamPolicy"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.setIamPolicy"},{"hostname":"bigqueryconnection.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigqueryconnection","resource_name":"bigqueryconnection.projects.locations.connections.testIamPermissions"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies/{dataPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.delete"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies)$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.list"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies/{dataPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.get"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies/{dataPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.patch"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies)$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.create"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies/{dataPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.getIamPolicy"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies/{dataPoliciesId}:rename","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.rename"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies/{dataPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.setIamPolicy"},{"hostname":"bigquerydatapolicy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataPolicies/{dataPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigquerydatapolicy","resource_name":"bigquerydatapolicy.projects.locations.dataPolicies.testIamPermissions"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.delete"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.dataSources.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.dataSources.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.dataSources.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.dataSources.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}/runs/{runsId}/transferLogs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferLogs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.runs.transferLogs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.get"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}/runs/{runsId}/transferLogs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferLogs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.runs.transferLogs.list"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.patch"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.patch"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/dataSources/{dataSourcesId}:checkValidCreds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkValidCreds)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.dataSources.checkValidCreds"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataSources/{dataSourcesId}:checkValidCreds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkValidCreds)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.dataSources.checkValidCreds"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.create"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}:scheduleRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::scheduleRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.scheduleRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/transferConfigs/{transferConfigsId}:startManualRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startManualRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.transferConfigs.startManualRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:enrollDataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enrollDataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.enrollDataSources"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:unenrollDataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unenrollDataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.locations.unenrollDataSources"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/transferConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.create"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}:scheduleRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::scheduleRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.scheduleRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/transferConfigs/{transferConfigsId}:startManualRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transferConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startManualRuns)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.transferConfigs.startManualRuns"},{"hostname":"bigquerydatatransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:enrollDataSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enrollDataSources)$","service_name":"google.bigquerydatatransfer","resource_name":"bigquerydatatransfer.projects.enrollDataSources"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservationGrants/{reservationGrantsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservationGrants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservationGrants.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/slotPools/{slotPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slotPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.slotPools.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.delete"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.getBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:searchAllAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAllAssignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchAllAssignments"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:searchAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAssignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchAssignments"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.operations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservationGrants","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservationGrants)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservationGrants.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/slotPools","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slotPools)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.slotPools.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/slotPools/{slotPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slotPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.slotPools.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}:SearchReservationGrants","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::SearchReservationGrants)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchReservationGrants"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.getBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.get"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.list"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}:searchAssignments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAssignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.searchAssignments"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.updateBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/{reservationsId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/biReservation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.updateBiReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.patch"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}:split","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::split)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.split"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/capacityCommitments:merge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments:merge)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.merge"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}:move","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.move"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}:failoverReservation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failoverReservation)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.failoverReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.operations.cancel"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservationGrants","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservationGrants)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservationGrants.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.createReservation"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments/{capacityCommitmentsId}:split","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::split)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.split"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/capacityCommitments:merge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capacityCommitments:merge)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.capacityCommitments.merge"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.create"},{"hostname":"bigqueryreservation.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/assignments/{assignmentsId}:move","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.bigqueryreservation","resource_name":"bigqueryreservation.projects.locations.reservations.assignments.move"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles/{appProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews/{authorizedViewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.delete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/operations/projects/{projectsId}/operations","path_regex":"^(?:/v2/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.operations.projects.operations.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/operations/{operationsId}","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.operations.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles/{appProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/hotTablets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hotTablets)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.hotTablets.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews/{authorizedViewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.get"},{"hostname":"bigtableadmin.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.locations.list"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.partialUpdateInstance"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles/{appProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.patch"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.partialUpdateCluster"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.patch"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.patch"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews/{authorizedViewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.patch"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/appProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appProfiles)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.appProfiles.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.getIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.setIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.testIamPermissions"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}/backups:copy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups:copy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.backups.copy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.create"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews/{authorizedViewsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.getIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews/{authorizedViewsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.setIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}/authorizedViews/{authorizedViewsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizedViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.authorizedViews.testIamPermissions"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:checkConsistency","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkConsistency)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.checkConsistency"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:dropRowRange","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::dropRowRange)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.dropRowRange"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:generateConsistencyToken","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConsistencyToken)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.generateConsistencyToken"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.getIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:modifyColumnFamilies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyColumnFamilies)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.modifyColumnFamilies"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.setIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.testIamPermissions"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables/{tablesId}:undelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.undelete"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/tables:restore","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables:restore)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.tables.restore"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.getIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.setIamPolicy"},{"hostname":"bigtableadmin.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.testIamPermissions"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.update"},{"hostname":"bigtableadmin.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/instances/{instancesId}/clusters/{clustersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.bigtableadmin","resource_name":"bigtableadmin.projects.instances.clusters.update"},{"hostname":"billingbudgets.googleapis.com","http_method":"DELETE","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.delete"},{"hostname":"billingbudgets.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.delete"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.list"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.get"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.list"},{"hostname":"billingbudgets.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.get"},{"hostname":"billingbudgets.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.patch"},{"hostname":"billingbudgets.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets/{budgetsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.patch"},{"hostname":"billingbudgets.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.create"},{"hostname":"billingbudgets.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/budgets","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/budgets)$","service_name":"google.billingbudgets","resource_name":"billingbudgets.billingAccounts.budgets.create"},{"hostname":"binaryauthorization.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.delete"},{"hostname":"binaryauthorization.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/platforms/{platformsId}/policies/{policiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.platforms.policies.delete"},{"hostname":"binaryauthorization.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.delete"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/policy","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.systempolicy.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/attestors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.list"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.get"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/platforms/{platformsId}/policies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.platforms.policies.list"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/platforms/{platformsId}/policies/{policiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.platforms.policies.get"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/policy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/policy:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/locations/{locationsId}/policy","path_regex":"^(?:/v1beta1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.systempolicy.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/attestors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.list"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.get"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/policy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.getPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/policy:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:getIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.getIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.create"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}:validateAttestationOccurrence","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateAttestationOccurrence)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.validateAttestationOccurrence"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/platforms/gke/policies/{policiesId}:evaluate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/gke/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluate)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.platforms.gke.policies.evaluate"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/platforms/{platformsId}/policies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.platforms.policies.create"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/policy:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/policy:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.create"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}:validateAttestationOccurrence","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateAttestationOccurrence)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.validateAttestationOccurrence"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/policy:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:setIamPolicy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.setIamPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/policy:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy:testIamPermissions)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.policy.testIamPermissions"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.update"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/platforms/{platformsId}/policies/{policiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.platforms.policies.replacePlatformPolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/policy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.updatePolicy"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/attestors/{attestorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attestors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.attestors.update"},{"hostname":"binaryauthorization.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/policy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policy)$","service_name":"google.binaryauthorization","resource_name":"binaryauthorization.projects.updatePolicy"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/blockchainNodes/{blockchainNodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blockchainNodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.blockchainNodes.delete"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.operations.delete"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.list"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.get"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/blockchainNodes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blockchainNodes)$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.blockchainNodes.list"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/blockchainNodes/{blockchainNodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blockchainNodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.blockchainNodes.get"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.operations.list"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.operations.get"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/blockchainNodes/{blockchainNodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blockchainNodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.blockchainNodes.patch"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/blockchainNodes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blockchainNodes)$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.blockchainNodes.create"},{"hostname":"blockchainnodeengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.blockchainnodeengine","resource_name":"blockchainnodeengine.projects.locations.operations.cancel"},{"hostname":"blogger.googleapis.com","http_method":"DELETE","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.delete"},{"hostname":"blogger.googleapis.com","http_method":"DELETE","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.delete"},{"hostname":"blogger.googleapis.com","http_method":"DELETE","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.delete"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogs.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/pages","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts/{postId}/comments","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/v2/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/users/{userId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.users.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v2/users/{userId}/blogs","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs)$","service_name":"google.blogger","resource_name":"blogger.blogs.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/byurl","path_regex":"^(?:/v3/blogs/byurl)$","service_name":"google.blogger","resource_name":"blogger.blogs.getByUrl"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogs.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/comments","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.listByBlog"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/pages","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/pageviews","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pageviews)$","service_name":"google.blogger","resource_name":"blogger.pageViews.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/bypath","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/bypath)$","service_name":"google.blogger","resource_name":"blogger.posts.getByPath"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/search","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/search)$","service_name":"google.blogger","resource_name":"blogger.posts.search"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.users.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs)$","service_name":"google.blogger","resource_name":"blogger.blogs.listByUser"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs/{blogId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogUserInfos.get"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs/{blogId}/posts","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.list"},{"hostname":"blogger.googleapis.com","http_method":"GET","path_template":"/v3/users/{userId}/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.get"},{"hostname":"blogger.googleapis.com","http_method":"PATCH","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.patch"},{"hostname":"blogger.googleapis.com","http_method":"PATCH","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.patch"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/pages","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.insert"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/pages/{pageId}/publish","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.blogger","resource_name":"blogger.pages.publish"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/pages/{pageId}/revert","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revert)$","service_name":"google.blogger","resource_name":"blogger.pages.revert"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.insert"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/approve","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approve)$","service_name":"google.blogger","resource_name":"blogger.comments.approve"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/removecontent","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removecontent)$","service_name":"google.blogger","resource_name":"blogger.comments.removeContent"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/spam","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spam)$","service_name":"google.blogger","resource_name":"blogger.comments.markAsSpam"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/publish","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.blogger","resource_name":"blogger.posts.publish"},{"hostname":"blogger.googleapis.com","http_method":"POST","path_template":"/v3/blogs/{blogId}/posts/{postId}/revert","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revert)$","service_name":"google.blogger","resource_name":"blogger.posts.revert"},{"hostname":"blogger.googleapis.com","http_method":"PUT","path_template":"/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.update"},{"hostname":"blogger.googleapis.com","http_method":"PUT","path_template":"/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.update"},{"hostname":"books.googleapis.com","http_method":"DELETE","path_template":"/books/v1/mylibrary/annotations/{annotationId}","path_regex":"^(?:/books/v1/mylibrary/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.annotations.delete"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/dictionary/listOfflineMetadata","path_regex":"^(?:/books/v1/dictionary/listOfflineMetadata)$","service_name":"google.books","resource_name":"books.dictionary.listOfflineMetadata"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/familysharing/getFamilyInfo","path_regex":"^(?:/books/v1/familysharing/getFamilyInfo)$","service_name":"google.books","resource_name":"books.familysharing.getFamilyInfo"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/myconfig/getUserSettings","path_regex":"^(?:/books/v1/myconfig/getUserSettings)$","service_name":"google.books","resource_name":"books.myconfig.getUserSettings"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/annotations","path_regex":"^(?:/books/v1/mylibrary/annotations)$","service_name":"google.books","resource_name":"books.mylibrary.annotations.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/bookshelves","path_regex":"^(?:/books/v1/mylibrary/bookshelves)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/bookshelves/{shelf}","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/volumes","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.volumes.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/mylibrary/readingpositions/{volumeId}","path_regex":"^(?:/books/v1/mylibrary/readingpositions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.readingpositions.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/notification/get","path_regex":"^(?:/books/v1/notification/get)$","service_name":"google.books","resource_name":"books.notification.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/onboarding/listCategories","path_regex":"^(?:/books/v1/onboarding/listCategories)$","service_name":"google.books","resource_name":"books.onboarding.listCategories"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/onboarding/listCategoryVolumes","path_regex":"^(?:/books/v1/onboarding/listCategoryVolumes)$","service_name":"google.books","resource_name":"books.onboarding.listCategoryVolumes"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/personalizedstream/get","path_regex":"^(?:/books/v1/personalizedstream/get)$","service_name":"google.books","resource_name":"books.personalizedstream.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/promooffer/get","path_regex":"^(?:/books/v1/promooffer/get)$","service_name":"google.books","resource_name":"books.promooffer.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/series/get","path_regex":"^(?:/books/v1/series/get)$","service_name":"google.books","resource_name":"books.series.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/series/membership/get","path_regex":"^(?:/books/v1/series/membership/get)$","service_name":"google.books","resource_name":"books.series.membership.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/users/{userId}/bookshelves","path_regex":"^(?:/books/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bookshelves)$","service_name":"google.books","resource_name":"books.bookshelves.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/users/{userId}/bookshelves/{shelf}","path_regex":"^(?:/books/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.bookshelves.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/users/{userId}/bookshelves/{shelf}/volumes","path_regex":"^(?:/books/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumes)$","service_name":"google.books","resource_name":"books.bookshelves.volumes.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes","path_regex":"^(?:/books/v1/volumes)$","service_name":"google.books","resource_name":"books.volumes.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/mybooks","path_regex":"^(?:/books/v1/volumes/mybooks)$","service_name":"google.books","resource_name":"books.volumes.mybooks.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/recommended","path_regex":"^(?:/books/v1/volumes/recommended)$","service_name":"google.books","resource_name":"books.volumes.recommended.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/useruploaded","path_regex":"^(?:/books/v1/volumes/useruploaded)$","service_name":"google.books","resource_name":"books.volumes.useruploaded.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.volumes.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/associated","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associated)$","service_name":"google.books","resource_name":"books.volumes.associated.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.volumeAnnotations.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}/annotations/{annotationId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.volumeAnnotations.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}/data","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data)$","service_name":"google.books","resource_name":"books.layers.annotationData.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layers/{layerId}/data/{annotationDataId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/data/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.annotationData.get"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layersummary","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layersummary)$","service_name":"google.books","resource_name":"books.layers.list"},{"hostname":"books.googleapis.com","http_method":"GET","path_template":"/books/v1/volumes/{volumeId}/layersummary/{summaryId}","path_regex":"^(?:/books/v1/volumes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/layersummary/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.layers.get"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/cloudloading/addBook","path_regex":"^(?:/books/v1/cloudloading/addBook)$","service_name":"google.books","resource_name":"books.cloudloading.addBook"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/cloudloading/deleteBook","path_regex":"^(?:/books/v1/cloudloading/deleteBook)$","service_name":"google.books","resource_name":"books.cloudloading.deleteBook"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/cloudloading/updateBook","path_regex":"^(?:/books/v1/cloudloading/updateBook)$","service_name":"google.books","resource_name":"books.cloudloading.updateBook"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/familysharing/share","path_regex":"^(?:/books/v1/familysharing/share)$","service_name":"google.books","resource_name":"books.familysharing.share"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/familysharing/unshare","path_regex":"^(?:/books/v1/familysharing/unshare)$","service_name":"google.books","resource_name":"books.familysharing.unshare"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/releaseDownloadAccess","path_regex":"^(?:/books/v1/myconfig/releaseDownloadAccess)$","service_name":"google.books","resource_name":"books.myconfig.releaseDownloadAccess"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/requestAccess","path_regex":"^(?:/books/v1/myconfig/requestAccess)$","service_name":"google.books","resource_name":"books.myconfig.requestAccess"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/syncVolumeLicenses","path_regex":"^(?:/books/v1/myconfig/syncVolumeLicenses)$","service_name":"google.books","resource_name":"books.myconfig.syncVolumeLicenses"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/myconfig/updateUserSettings","path_regex":"^(?:/books/v1/myconfig/updateUserSettings)$","service_name":"google.books","resource_name":"books.myconfig.updateUserSettings"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/annotations","path_regex":"^(?:/books/v1/mylibrary/annotations)$","service_name":"google.books","resource_name":"books.mylibrary.annotations.insert"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/annotations/summary","path_regex":"^(?:/books/v1/mylibrary/annotations/summary)$","service_name":"google.books","resource_name":"books.mylibrary.annotations.summary"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/addVolume","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addVolume)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.addVolume"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/clearVolumes","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clearVolumes)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.clearVolumes"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/moveVolume","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveVolume)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.moveVolume"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/bookshelves/{shelf}/removeVolume","path_regex":"^(?:/books/v1/mylibrary/bookshelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeVolume)$","service_name":"google.books","resource_name":"books.mylibrary.bookshelves.removeVolume"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/mylibrary/readingpositions/{volumeId}/setPosition","path_regex":"^(?:/books/v1/mylibrary/readingpositions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPosition)$","service_name":"google.books","resource_name":"books.mylibrary.readingpositions.setPosition"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/promooffer/accept","path_regex":"^(?:/books/v1/promooffer/accept)$","service_name":"google.books","resource_name":"books.promooffer.accept"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/promooffer/dismiss","path_regex":"^(?:/books/v1/promooffer/dismiss)$","service_name":"google.books","resource_name":"books.promooffer.dismiss"},{"hostname":"books.googleapis.com","http_method":"POST","path_template":"/books/v1/volumes/recommended/rate","path_regex":"^(?:/books/v1/volumes/recommended/rate)$","service_name":"google.books","resource_name":"books.volumes.recommended.rate"},{"hostname":"books.googleapis.com","http_method":"PUT","path_template":"/books/v1/mylibrary/annotations/{annotationId}","path_regex":"^(?:/books/v1/mylibrary/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.books","resource_name":"books.mylibrary.annotations.update"},{"hostname":"businessprofileperformance.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/searchkeywords/impressions/monthly","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchkeywords/impressions/monthly)$","service_name":"google.businessprofileperformance","resource_name":"businessprofileperformance.locations.searchkeywords.impressions.monthly.list"},{"hostname":"businessprofileperformance.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}:fetchMultiDailyMetricsTimeSeries","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchMultiDailyMetricsTimeSeries)$","service_name":"google.businessprofileperformance","resource_name":"businessprofileperformance.locations.fetchMultiDailyMetricsTimeSeries"},{"hostname":"businessprofileperformance.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}:getDailyMetricsTimeSeries","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDailyMetricsTimeSeries)$","service_name":"google.businessprofileperformance","resource_name":"businessprofileperformance.locations.getDailyMetricsTimeSeries"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs/{certificateIssuanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries/{certificateMapEntriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations/{dnsAuthorizationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs/{trustConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.delete"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs/{certificateIssuanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries/{certificateMapEntriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations/{dnsAuthorizationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.list"},{"hostname":"certificatemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs/{trustConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.get"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs/{certificateIssuanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries/{certificateMapEntriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations/{dnsAuthorizationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs/{trustConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.patch"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateIssuanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateIssuanceConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateIssuanceConfigs.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateMaps/{certificateMapsId}/certificateMapEntries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateMapEntries)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificateMaps.certificateMapEntries.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.certificates.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsAuthorizations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsAuthorizations)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.dnsAuthorizations.create"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.operations.cancel"},{"hostname":"certificatemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/trustConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trustConfigs)$","service_name":"google.certificatemanager","resource_name":"certificatemanager.projects.locations.trustConfigs.create"},{"hostname":"chat.googleapis.com","http_method":"DELETE","path_template":"/v1/spaces/{spacesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.delete"},{"hostname":"chat.googleapis.com","http_method":"DELETE","path_template":"/v1/spaces/{spacesId}/members/{membersId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.members.delete"},{"hostname":"chat.googleapis.com","http_method":"DELETE","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.delete"},{"hostname":"chat.googleapis.com","http_method":"DELETE","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}/reactions/{reactionsId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reactions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.reactions.delete"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.media.download"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces","path_regex":"^(?:/v1/spaces)$","service_name":"google.chat","resource_name":"chat.spaces.list"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/members","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.chat","resource_name":"chat.spaces.members.list"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/members/{membersId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.members.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/messages","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.chat","resource_name":"chat.spaces.messages.list"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.attachments.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}/reactions","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reactions)$","service_name":"google.chat","resource_name":"chat.spaces.messages.reactions.list"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/spaceEvents","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spaceEvents)$","service_name":"google.chat","resource_name":"chat.spaces.spaceEvents.list"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces/{spacesId}/spaceEvents/{spaceEventsId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spaceEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.spaceEvents.get"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/spaces:findDirectMessage","path_regex":"^(?:/v1/spaces:findDirectMessage)$","service_name":"google.chat","resource_name":"chat.spaces.findDirectMessage"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/spaces/{spacesId}/spaceReadState","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spaceReadState)$","service_name":"google.chat","resource_name":"chat.users.spaces.getSpaceReadState"},{"hostname":"chat.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/spaces/{spacesId}/threads/{threadsId}/threadReadState","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threadReadState)$","service_name":"google.chat","resource_name":"chat.users.spaces.threads.getThreadReadState"},{"hostname":"chat.googleapis.com","http_method":"PATCH","path_template":"/v1/spaces/{spacesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.patch"},{"hostname":"chat.googleapis.com","http_method":"PATCH","path_template":"/v1/spaces/{spacesId}/members/{membersId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.members.patch"},{"hostname":"chat.googleapis.com","http_method":"PATCH","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.patch"},{"hostname":"chat.googleapis.com","http_method":"PATCH","path_template":"/v1/users/{usersId}/spaces/{spacesId}/spaceReadState","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spaceReadState)$","service_name":"google.chat","resource_name":"chat.users.spaces.updateSpaceReadState"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces","path_regex":"^(?:/v1/spaces)$","service_name":"google.chat","resource_name":"chat.spaces.create"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces/{spacesId}/attachments:upload","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments:upload)$","service_name":"google.chat","resource_name":"chat.media.upload"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces/{spacesId}/members","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.chat","resource_name":"chat.spaces.members.create"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces/{spacesId}/messages","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.chat","resource_name":"chat.spaces.messages.create"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}/reactions","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reactions)$","service_name":"google.chat","resource_name":"chat.spaces.messages.reactions.create"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces/{spacesId}:completeImport","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeImport)$","service_name":"google.chat","resource_name":"chat.spaces.completeImport"},{"hostname":"chat.googleapis.com","http_method":"POST","path_template":"/v1/spaces:setup","path_regex":"^(?:/v1/spaces:setup)$","service_name":"google.chat","resource_name":"chat.spaces.setup"},{"hostname":"chat.googleapis.com","http_method":"PUT","path_template":"/v1/spaces/{spacesId}/messages/{messagesId}","path_regex":"^(?:/v1/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chat","resource_name":"chat.spaces.messages.update"},{"hostname":"checks.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.checks","resource_name":"checks.accounts.apps.operations.delete"},{"hostname":"checks.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/apps","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps)$","service_name":"google.checks","resource_name":"checks.accounts.apps.list"},{"hostname":"checks.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.checks","resource_name":"checks.accounts.apps.get"},{"hostname":"checks.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/operations","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.checks","resource_name":"checks.accounts.apps.operations.list"},{"hostname":"checks.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.checks","resource_name":"checks.accounts.apps.operations.get"},{"hostname":"checks.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/reports","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.checks","resource_name":"checks.accounts.apps.reports.list"},{"hostname":"checks.googleapis.com","http_method":"GET","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/reports/{reportsId}","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.checks","resource_name":"checks.accounts.apps.reports.get"},{"hostname":"checks.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.checks","resource_name":"checks.accounts.apps.operations.cancel"},{"hostname":"checks.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.checks","resource_name":"checks.accounts.apps.operations.wait"},{"hostname":"checks.googleapis.com","http_method":"POST","path_template":"/v1alpha/accounts/{accountsId}/apps/{appsId}/reports:analyzeUpload","path_regex":"^(?:/v1alpha/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:analyzeUpload)$","service_name":"google.checks","resource_name":"checks.media.upload"},{"hostname":"chromemanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/customers/{customersId}/telemetry/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.notificationConfigs.delete"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps/android/{androidId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/android/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.android.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps/chrome/{chromeId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/chrome/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.chrome.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps/web/{webId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/web/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.web.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps:countChromeAppRequests","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps:countChromeAppRequests)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.countChromeAppRequests"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps:fetchDevicesRequestingExtension","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps:fetchDevicesRequestingExtension)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.fetchDevicesRequestingExtension"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/apps:fetchUsersRequestingExtension","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps:fetchUsersRequestingExtension)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.apps.fetchUsersRequestingExtension"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeBrowsersNeedingAttention","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeBrowsersNeedingAttention)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeBrowsersNeedingAttention"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeCrashEvents","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeCrashEvents)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeCrashEvents"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeDevicesReachingAutoExpirationDate","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeDevicesReachingAutoExpirationDate)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeDevicesReachingAutoExpirationDate"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeDevicesThatNeedAttention","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeDevicesThatNeedAttention)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeDevicesThatNeedAttention"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeHardwareFleetDevices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeHardwareFleetDevices)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeHardwareFleetDevices"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countChromeVersions","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countChromeVersions)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countChromeVersions"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countInstalledApps","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countInstalledApps)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countInstalledApps"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countPrintJobsByPrinter","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countPrintJobsByPrinter)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countPrintJobsByPrinter"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:countPrintJobsByUser","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:countPrintJobsByUser)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.countPrintJobsByUser"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:enumeratePrintJobs","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:enumeratePrintJobs)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.enumeratePrintJobs"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/reports:findInstalledAppDevices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:findInstalledAppDevices)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.reports.findInstalledAppDevices"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/devices","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/devices)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.devices.list"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/devices/{devicesId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.devices.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/events","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/events)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.events.list"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/notificationConfigs","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/notificationConfigs)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.notificationConfigs.list"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/users","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/users)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.users.list"},{"hostname":"chromemanagement.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/telemetry/users/{usersId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.users.get"},{"hostname":"chromemanagement.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/telemetry/notificationConfigs","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/telemetry/notificationConfigs)$","service_name":"google.chromemanagement","resource_name":"chromemanagement.customers.telemetry.notificationConfigs.create"},{"hostname":"chromepolicy.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/policySchemas","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policySchemas)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policySchemas.list"},{"hostname":"chromepolicy.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/policySchemas/{policySchemasId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policySchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policySchemas.get"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/files:uploadPolicyFile","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/files:uploadPolicyFile)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.media.upload"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:batchDelete","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:batchDelete)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.batchDelete"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:batchModify","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:batchModify)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.batchModify"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:listGroupPriorityOrdering","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:listGroupPriorityOrdering)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.listGroupPriorityOrdering"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/groups:updateGroupPriorityOrdering","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/groups:updateGroupPriorityOrdering)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.groups.updateGroupPriorityOrdering"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:defineCertificate","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:defineCertificate)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.defineCertificate"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:defineNetwork","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:defineNetwork)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.defineNetwork"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:removeCertificate","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:removeCertificate)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.removeCertificate"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/networks:removeNetwork","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/networks:removeNetwork)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.networks.removeNetwork"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/orgunits:batchInherit","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/orgunits:batchInherit)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.orgunits.batchInherit"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies/orgunits:batchModify","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/orgunits:batchModify)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.orgunits.batchModify"},{"hostname":"chromepolicy.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/policies:resolve","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies:resolve)$","service_name":"google.chromepolicy","resource_name":"chromepolicy.customers.policies.resolve"},{"hostname":"chromeuxreport.googleapis.com","http_method":"POST","path_template":"/v1/records:queryHistoryRecord","path_regex":"^(?:/v1/records:queryHistoryRecord)$","service_name":"google.chromeuxreport","resource_name":"chromeuxreport.records.queryHistoryRecord"},{"hostname":"chromeuxreport.googleapis.com","http_method":"POST","path_template":"/v1/records:queryRecord","path_regex":"^(?:/v1/records:queryRecord)$","service_name":"google.chromeuxreport","resource_name":"chromeuxreport.records.queryRecord"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/divisions","path_regex":"^(?:/civicinfo/v2/divisions)$","service_name":"google.civicinfo","resource_name":"civicinfo.divisions.search"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/elections","path_regex":"^(?:/civicinfo/v2/elections)$","service_name":"google.civicinfo","resource_name":"civicinfo.elections.electionQuery"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/representatives","path_regex":"^(?:/civicinfo/v2/representatives)$","service_name":"google.civicinfo","resource_name":"civicinfo.representatives.representativeInfoByAddress"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/representatives/{ocdId}","path_regex":"^(?:/civicinfo/v2/representatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.civicinfo","resource_name":"civicinfo.representatives.representativeInfoByDivision"},{"hostname":"civicinfo.googleapis.com","http_method":"GET","path_template":"/civicinfo/v2/voterinfo","path_regex":"^(?:/civicinfo/v2/voterinfo)$","service_name":"google.civicinfo","resource_name":"civicinfo.elections.voterInfoQuery"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/aliases/{alias}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.aliases.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/announcements/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/announcements/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.addOnAttachments.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/courseWork/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.addOnAttachments.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.addOnAttachments.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.posts.addOnAttachments.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/students/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.students.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/teachers/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{courseId}/topics/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.topics.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/invitations/{id}","path_regex":"^(?:/v1/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.invitations.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/registrations/{registrationId}","path_regex":"^(?:/v1/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.registrations.delete"},{"hostname":"classroom.googleapis.com","http_method":"DELETE","path_template":"/v1/userProfiles/{studentId}/guardians/{guardianId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardians/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardians.delete"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses","path_regex":"^(?:/v1/courses)$","service_name":"google.classroom","resource_name":"classroom.courses.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/aliases","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.classroom","resource_name":"classroom.courses.aliases.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/announcements","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/announcements/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/announcements/{itemId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.addOnAttachments.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/announcements/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.addOnAttachments.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/announcements/{itemId}/addOnContext","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnContext)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.getAddOnContext"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.addOnAttachments.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.addOnAttachments.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnAttachments/{attachmentId}/studentSubmissions/{submissionId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.addOnAttachments.studentSubmissions.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnContext","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnContext)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.getAddOnContext"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWorkMaterials","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{itemId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.addOnAttachments.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.addOnAttachments.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{itemId}/addOnContext","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnContext)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.getAddOnContext"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.posts.addOnAttachments.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.posts.addOnAttachments.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnAttachments/{attachmentId}/studentSubmissions/{submissionId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.posts.addOnAttachments.studentSubmissions.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnContext","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnContext)$","service_name":"google.classroom","resource_name":"classroom.courses.posts.getAddOnContext"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/students","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students)$","service_name":"google.classroom","resource_name":"classroom.courses.students.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/students/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.students.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/teachers","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers)$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/teachers/{userId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/topics","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.classroom","resource_name":"classroom.courses.topics.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{courseId}/topics/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.topics.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/invitations","path_regex":"^(?:/v1/invitations)$","service_name":"google.classroom","resource_name":"classroom.invitations.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/invitations/{id}","path_regex":"^(?:/v1/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.invitations.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardianInvitations","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations)$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardianInvitations/{invitationId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardians","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardians)$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardians.list"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{studentId}/guardians/{guardianId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardians/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardians.get"},{"hostname":"classroom.googleapis.com","http_method":"GET","path_template":"/v1/userProfiles/{userId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.get"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/announcements/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/announcements/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.addOnAttachments.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWork/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.addOnAttachments.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnAttachments/{attachmentId}/studentSubmissions/{submissionId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.addOnAttachments.studentSubmissions.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{itemId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.addOnAttachments.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnAttachments/{attachmentId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.posts.addOnAttachments.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnAttachments/{attachmentId}/studentSubmissions/{submissionId}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.posts.addOnAttachments.studentSubmissions.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{courseId}/topics/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.topics.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.patch"},{"hostname":"classroom.googleapis.com","http_method":"PATCH","path_template":"/v1/userProfiles/{studentId}/guardianInvitations/{invitationId}","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.patch"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses","path_regex":"^(?:/v1/courses)$","service_name":"google.classroom","resource_name":"classroom.courses.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/aliases","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aliases)$","service_name":"google.classroom","resource_name":"classroom.courses.aliases.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/announcements","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/announcements/{id}:modifyAssignees","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAssignees)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.modifyAssignees"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/announcements/{itemId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announcements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.announcements.addOnAttachments.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:modifyAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.modifyAttachments"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:reclaim","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reclaim)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.reclaim"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:return","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::return)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.return"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{courseWorkId}/studentSubmissions/{id}:turnIn","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studentSubmissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::turnIn)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.studentSubmissions.turnIn"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{id}:modifyAssignees","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAssignees)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.modifyAssignees"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWork/{itemId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWork/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWork.addOnAttachments.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWorkMaterials","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/courseWorkMaterials/{itemId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/courseWorkMaterials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.courseWorkMaterials.addOnAttachments.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/posts/{postId}/addOnAttachments","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addOnAttachments)$","service_name":"google.classroom","resource_name":"classroom.courses.posts.addOnAttachments.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/students","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/students)$","service_name":"google.classroom","resource_name":"classroom.courses.students.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/teachers","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/teachers)$","service_name":"google.classroom","resource_name":"classroom.courses.teachers.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/courses/{courseId}/topics","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.classroom","resource_name":"classroom.courses.topics.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/invitations","path_regex":"^(?:/v1/invitations)$","service_name":"google.classroom","resource_name":"classroom.invitations.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/invitations/{id}:accept","path_regex":"^(?:/v1/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.classroom","resource_name":"classroom.invitations.accept"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/registrations","path_regex":"^(?:/v1/registrations)$","service_name":"google.classroom","resource_name":"classroom.registrations.create"},{"hostname":"classroom.googleapis.com","http_method":"POST","path_template":"/v1/userProfiles/{studentId}/guardianInvitations","path_regex":"^(?:/v1/userProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guardianInvitations)$","service_name":"google.classroom","resource_name":"classroom.userProfiles.guardianInvitations.create"},{"hostname":"classroom.googleapis.com","http_method":"PUT","path_template":"/v1/courses/{id}","path_regex":"^(?:/v1/courses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.classroom","resource_name":"classroom.courses.update"},{"hostname":"cloudasset.googleapis.com","http_method":"DELETE","path_template":"/v1/{v1Id}/{v1Id1}/feeds/{feedsId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.delete"},{"hostname":"cloudasset.googleapis.com","http_method":"DELETE","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.delete"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/assets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.cloudasset","resource_name":"cloudasset.assets.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/effectiveIamPolicies:batchGet","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/effectiveIamPolicies:batchGet)$","service_name":"google.cloudasset","resource_name":"cloudasset.effectiveIamPolicies.batchGet"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/feeds","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds)$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/feeds/{feedsId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeIamPolicy)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeIamPolicy"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeMove","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeMove)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeMove"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeOrgPolicies","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeOrgPolicies)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeOrgPolicies"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeOrgPolicyGovernedAssets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeOrgPolicyGovernedAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeOrgPolicyGovernedAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:analyzeOrgPolicyGovernedContainers","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeOrgPolicyGovernedContainers)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeOrgPolicyGovernedContainers"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:batchGetAssetsHistory","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchGetAssetsHistory)$","service_name":"google.cloudasset","resource_name":"cloudasset.batchGetAssetsHistory"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:searchAllIamPolicies","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAllIamPolicies)$","service_name":"google.cloudasset","resource_name":"cloudasset.searchAllIamPolicies"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}:searchAllResources","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchAllResources)$","service_name":"google.cloudasset","resource_name":"cloudasset.searchAllResources"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.folders.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.organizations.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}:batchGetAssetsHistory","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchGetAssetsHistory)$","service_name":"google.cloudasset","resource_name":"cloudasset.organizations.batchGetAssetsHistory"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.projects.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}:batchGetAssetsHistory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchGetAssetsHistory)$","service_name":"google.cloudasset","resource_name":"cloudasset.projects.batchGetAssetsHistory"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/{v1p1beta1Id}/{v1p1beta1Id1}/iamPolicies:searchAll","path_regex":"^(?:/v1p1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iamPolicies:searchAll)$","service_name":"google.cloudasset","resource_name":"cloudasset.iamPolicies.searchAll"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/{v1p1beta1Id}/{v1p1beta1Id1}/resources:searchAll","path_regex":"^(?:/v1p1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources:searchAll)$","service_name":"google.cloudasset","resource_name":"cloudasset.resources.searchAll"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p4beta1/{v1p4beta1Id}/{v1p4beta1Id1}:analyzeIamPolicy","path_regex":"^(?:/v1p4beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeIamPolicy)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeIamPolicy"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p5beta1/{v1p5beta1Id}/{v1p5beta1Id1}/assets","path_regex":"^(?:/v1p5beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.cloudasset","resource_name":"cloudasset.assets.list"},{"hostname":"cloudasset.googleapis.com","http_method":"GET","path_template":"/v1p7beta1/{v1p7beta1Id}/{v1p7beta1Id1}/operations/{operationsId}/{operationsId1}","path_regex":"^(?:/v1p7beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.operations.get"},{"hostname":"cloudasset.googleapis.com","http_method":"PATCH","path_template":"/v1/{v1Id}/{v1Id1}/feeds/{feedsId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.patch"},{"hostname":"cloudasset.googleapis.com","http_method":"PATCH","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.patch"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/feeds","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feeds)$","service_name":"google.cloudasset","resource_name":"cloudasset.feeds.create"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/savedQueries","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.cloudasset","resource_name":"cloudasset.savedQueries.create"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}:analyzeIamPolicyLongrunning","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeIamPolicyLongrunning)$","service_name":"google.cloudasset","resource_name":"cloudasset.analyzeIamPolicyLongrunning"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}:exportAssets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}:queryAssets","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.queryAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}:exportAssets","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.folders.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:exportAssets","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.organizations.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:exportAssets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.projects.exportAssets"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1p4beta1/{v1p4beta1Id}/{v1p4beta1Id1}:exportIamPolicyAnalysis","path_regex":"^(?:/v1p4beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportIamPolicyAnalysis)$","service_name":"google.cloudasset","resource_name":"cloudasset.exportIamPolicyAnalysis"},{"hostname":"cloudasset.googleapis.com","http_method":"POST","path_template":"/v1p7beta1/{v1p7beta1Id}/{v1p7beta1Id1}:exportAssets","path_regex":"^(?:/v1p7beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAssets)$","service_name":"google.cloudasset","resource_name":"cloudasset.exportAssets"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts","path_regex":"^(?:/v1/billingAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/projects","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.projects.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/subAccounts","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.subAccounts.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}:getIamPolicy","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.getIamPolicy"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/billingAccounts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.organizations.billingAccounts.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/billingAccounts/{billingAccountsId}:move","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.organizations.billingAccounts.move"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/billingInfo","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingInfo)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.projects.getBillingInfo"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/services","path_regex":"^(?:/v1/services)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.services.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/skus","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.services.skus.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/services","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.services.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/services/{servicesId}","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.services.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skuGroups","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skuGroups)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skuGroups.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skuGroups/{skuGroupsId}","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skuGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skuGroups.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skuGroups/{skuGroupsId}/skus","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skuGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skuGroups.skus.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skuGroups/{skuGroupsId}/skus/{skusId}","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skuGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skuGroups.skus.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skus","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skus.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skus/{skusId}","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skus.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skus/{skusId}/price","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/price)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skus.price.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/billingAccounts/{billingAccountsId}/skus/{skusId}/prices","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prices)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.skus.prices.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/skuGroups","path_regex":"^(?:/v1beta/skuGroups)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.skuGroups.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/skuGroups/{skuGroupsId}","path_regex":"^(?:/v1beta/skuGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.skuGroups.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/skuGroups/{skuGroupsId}/skus","path_regex":"^(?:/v1beta/skuGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.skuGroups.skus.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/skuGroups/{skuGroupsId}/skus/{skusId}","path_regex":"^(?:/v1beta/skuGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.skuGroups.skus.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/skus/{skusId}/price","path_regex":"^(?:/v1beta/skus/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/price)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.skus.price.get"},{"hostname":"cloudbilling.googleapis.com","http_method":"GET","path_template":"/v1beta/skus/{skusId}/prices","path_regex":"^(?:/v1beta/skus/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prices)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.skus.prices.list"},{"hostname":"cloudbilling.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.patch"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts","path_regex":"^(?:/v1/billingAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.create"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/subAccounts","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.subAccounts.create"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}:move","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.move"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}:setIamPolicy","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.setIamPolicy"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}:testIamPermissions","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.testIamPermissions"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/billingAccounts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingAccounts)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.organizations.billingAccounts.create"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1beta/billingAccounts/{billingAccountsId}:estimateCostScenario","path_regex":"^(?:/v1beta/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::estimateCostScenario)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.billingAccounts.estimateCostScenario"},{"hostname":"cloudbilling.googleapis.com","http_method":"POST","path_template":"/v1beta:estimateCostScenario","path_regex":"^(?:/v1beta:estimateCostScenario)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.estimateCostScenario"},{"hostname":"cloudbilling.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/billingInfo","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingInfo)$","service_name":"google.cloudbilling","resource_name":"cloudbilling.projects.updateBillingInfo"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/triggers/{triggerId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories/{repositoriesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.delete"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/builds/{id}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/triggers/{triggerId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.repos.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/defaultServiceAccount","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultServiceAccount)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.getDefaultServiceAccount"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.repos.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.list"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories/{repositoriesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories/{repositoriesId}:fetchGitRefs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchGitRefs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.fetchGitRefs"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:fetchLinkableRepositories","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchLinkableRepositories)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.fetchLinkableRepositories"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.getIamPolicy"},{"hostname":"cloudbuild.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.get"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/triggers/{triggerId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs/{githubEnterpriseConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools/{workerPoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.patch"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/githubDotComWebhook:receive","path_regex":"^(?:/v1/githubDotComWebhook:receive)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.githubDotComWebhook.receive"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/regionalWebhook","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalWebhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.locations.regionalWebhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/builds/{id}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/builds/{id}:retry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retry)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.retry"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/triggers/{triggerId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.run"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/triggers/{trigger}:webhook","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::webhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.triggers.webhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/builds/{buildsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.builds.approve"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.githubEnterpriseConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}/connectedRepositories:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectedRepositories:batchCreate)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.connectedRepositories.batchCreate"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bitbucketServerConfigs/{bitbucketServerConfigsId}:removeBitbucketServerConnectedRepository","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bitbucketServerConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeBitbucketServerConnectedRepository)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.bitbucketServerConfigs.removeBitbucketServerConnectedRepository"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.approve"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/builds/{buildsId}:retry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/builds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retry)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.builds.retry"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}/connectedRepositories:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectedRepositories:batchCreate)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.connectedRepositories.batchCreate"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gitLabConfigs/{gitLabConfigsId}:removeGitLabConnectedRepository","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitLabConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeGitLabConnectedRepository)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.gitLabConfigs.removeGitLabConnectedRepository"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/githubEnterpriseConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/githubEnterpriseConfigs)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.githubEnterpriseConfigs.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.run"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:webhook","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::webhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.triggers.webhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1/webhook","path_regex":"^(?:/v1/webhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.webhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/workerPools","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.workerPools.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/workerPools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workerPools)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.workerPools.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.create"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories/{repositoriesId}:accessReadToken","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accessReadToken)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.accessReadToken"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories/{repositoriesId}:accessReadWriteToken","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accessReadWriteToken)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.accessReadWriteToken"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/repositories:batchCreate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories:batchCreate)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.repositories.batchCreate"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.setIamPolicy"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.testIamPermissions"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections:processWebhook","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections:processWebhook)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.connections.processWebhook"},{"hostname":"cloudbuild.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudbuild","resource_name":"cloudbuild.projects.locations.operations.cancel"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs/{channelPartnerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs/{customerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.delete"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs/{channelPartnerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs/{customerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:listEntitlementChanges","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listEntitlementChanges)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.listEntitlementChanges"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:lookupOffer","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupOffer)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.lookupOffer"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:listPurchasableOffers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listPurchasableOffers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.listPurchasableOffers"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:listPurchasableSkus","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listPurchasableSkus)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.listPurchasableSkus"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:queryEligibleBillingAccounts","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryEligibleBillingAccounts)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.queryEligibleBillingAccounts"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/offers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/offers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.offers.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/reports","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.reports.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/skuGroups","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skuGroups)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.skuGroups.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/skuGroups/{skuGroupsId}/billableSkus","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skuGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billableSkus)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.skuGroups.billableSkus.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}:listSubscribers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSubscribers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.listSubscribers"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/integrators/{integratorsId}:listSubscribers","path_regex":"^(?:/v1/integrators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSubscribers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.integrators.listSubscribers"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.get"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/products","path_regex":"^(?:/v1/products)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.products.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"GET","path_template":"/v1/products/{productsId}/skus","path_regex":"^(?:/v1/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/skus)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.products.skus.list"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs/{channelPartnerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/customers/{customersId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs/{customerRepricingConfigsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.patch"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/channelPartnerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.channelPartnerRepricingConfigs.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/channelPartnerLinks/{channelPartnerLinksId}/customers:import","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelPartnerLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers:import)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.channelPartnerLinks.customers.import"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/customerRepricingConfigs","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customerRepricingConfigs)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.customerRepricingConfigs.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.create"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:activate","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.activate"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:cancel","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.cancel"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:changeOffer","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::changeOffer)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.changeOffer"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:changeParameters","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::changeParameters)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.changeParameters"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:changeRenewalSettings","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::changeRenewalSettings)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.changeRenewalSettings"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:startPaidService","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startPaidService)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.startPaidService"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}/entitlements/{entitlementsId}:suspend","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::suspend)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.entitlements.suspend"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:provisionCloudIdentity","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::provisionCloudIdentity)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.provisionCloudIdentity"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:transferEntitlements","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::transferEntitlements)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.transferEntitlements"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers/{customersId}:transferEntitlementsToGoogle","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::transferEntitlementsToGoogle)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.transferEntitlementsToGoogle"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/customers:import","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers:import)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.customers.import"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/reportJobs/{reportJobsId}:fetchReportResults","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchReportResults)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.reportJobs.fetchReportResults"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/reports/{reportsId}:run","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.reports.run"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:checkCloudIdentityAccountsExist","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkCloudIdentityAccountsExist)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.checkCloudIdentityAccountsExist"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:listTransferableOffers","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTransferableOffers)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.listTransferableOffers"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:listTransferableSkus","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTransferableSkus)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.listTransferableSkus"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:register","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::register)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.register"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:unregister","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unregister)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.accounts.unregister"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/integrators/{integratorsId}:register","path_regex":"^(?:/v1/integrators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::register)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.integrators.register"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/integrators/{integratorsId}:unregister","path_regex":"^(?:/v1/integrators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unregister)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.integrators.unregister"},{"hostname":"cloudchannel.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudchannel","resource_name":"cloudchannel.operations.cancel"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/accounts","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.list"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/accounts/{accountsId}","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.get"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/entitlements","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.list"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"GET","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.get"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"PATCH","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.patch"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/accounts/{accountsId}:approve","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.approve"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/accounts/{accountsId}:reject","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.reject"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/accounts/{accountsId}:reset","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.accounts.reset"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:approve","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.approve"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:approvePlanChange","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approvePlanChange)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.approvePlanChange"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:reject","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.reject"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:rejectPlanChange","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rejectPlanChange)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.rejectPlanChange"},{"hostname":"cloudcommerceprocurement.googleapis.com","http_method":"POST","path_template":"/v1/providers/{providersId}/entitlements/{entitlementsId}:suspend","path_regex":"^(?:/v1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::suspend)$","service_name":"google.cloudcommerceprocurement","resource_name":"cloudcommerceprocurement.providers.entitlements.suspend"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.get"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.get"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/accessApprovalRequests","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalRequests)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.accessApprovalRequests.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/ekmConnections","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.getEkmConnections"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/partnerPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partnerPermissions)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.getPartnerPermissions"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/violations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.violations.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/violations/{violationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.violations.get"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/partner","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partner)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.getPartner"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.get"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.get"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/accessApprovalRequests","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessApprovalRequests)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.accessApprovalRequests.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/ekmConnections","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.getEkmConnections"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/partnerPermissions","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partnerPermissions)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.getPartnerPermissions"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/violations","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.violations.list"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/customers/{customersId}/workloads/{workloadsId}/violations/{violationsId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/violations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.customers.workloads.violations.get"},{"hostname":"cloudcontrolspartner.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/partner","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partner)$","service_name":"google.cloudcontrolspartner","resource_name":"cloudcontrolspartner.organizations.locations.getPartner"},{"hostname":"clouddebugger.googleapis.com","http_method":"DELETE","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints/{breakpointId}","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.delete"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/controller/debuggees/{debuggeeId}/breakpoints","path_regex":"^(?:/v2/controller/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.controller.debuggees.breakpoints.list"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/debugger/debuggees","path_regex":"^(?:/v2/debugger/debuggees)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.list"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.list"},{"hostname":"clouddebugger.googleapis.com","http_method":"GET","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints/{breakpointId}","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.get"},{"hostname":"clouddebugger.googleapis.com","http_method":"POST","path_template":"/v2/controller/debuggees/register","path_regex":"^(?:/v2/controller/debuggees/register)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.controller.debuggees.register"},{"hostname":"clouddebugger.googleapis.com","http_method":"POST","path_template":"/v2/debugger/debuggees/{debuggeeId}/breakpoints/set","path_regex":"^(?:/v2/debugger/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/set)$","service_name":"google.clouddebugger","resource_name":"clouddebugger.debugger.debuggees.breakpoints.set"},{"hostname":"clouddebugger.googleapis.com","http_method":"PUT","path_template":"/v2/controller/debuggees/{debuggeeId}/breakpoints/{id}","path_regex":"^(?:/v2/controller/debuggees/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/breakpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddebugger","resource_name":"clouddebugger.controller.debuggees.breakpoints.update"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customTargetTypes/{customTargetTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customTargetTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.customTargetTypes.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automations/{automationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automations.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.delete"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.getConfig"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customTargetTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customTargetTypes)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.customTargetTypes.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customTargetTypes/{customTargetTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customTargetTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.customTargetTypes.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customTargetTypes/{customTargetTypesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customTargetTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.customTargetTypes.getIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automationRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automationRuns)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automationRuns.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automationRuns/{automationRunsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automationRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automationRuns.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automations)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automations.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automations/{automationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automations.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}/jobRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobRuns)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.jobRuns.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}/jobRuns/{jobRunsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.jobRuns.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.getIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.list"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.get"},{"hostname":"clouddeploy.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.getIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customTargetTypes/{customTargetTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customTargetTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.customTargetTypes.patch"},{"hostname":"clouddeploy.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.patch"},{"hostname":"clouddeploy.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automations/{automationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automations.patch"},{"hostname":"clouddeploy.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.patch"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customTargetTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customTargetTypes)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.customTargetTypes.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customTargetTypes/{customTargetTypesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customTargetTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.customTargetTypes.setIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automationRuns/{automationRunsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automationRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automationRuns.cancel"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/automations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/automations)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.automations.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}/jobRuns/{jobRunsId}:terminate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::terminate)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.jobRuns.terminate"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:advance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::advance)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.advance"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:approve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.approve"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.cancel"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:ignoreJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::ignoreJob)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.ignoreJob"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}/rollouts/{rolloutsId}:retryJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retryJob)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.rollouts.retryJob"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}/releases/{releasesId}:abandon","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::abandon)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.releases.abandon"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}:rollbackTarget","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollbackTarget)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.rollbackTarget"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.setIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deliveryPipelines/{deliveryPipelinesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryPipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.deliveryPipelines.testIamPermissions"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.operations.cancel"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.create"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.setIamPolicy"},{"hostname":"clouddeploy.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targets/{targetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.clouddeploy","resource_name":"clouddeploy.projects.locations.targets.testIamPermissions"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/events","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.deleteEvents"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/events","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.locations.deleteEvents"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/events","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.events.list"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/groupStats","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupStats)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.groupStats.list"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.groups.get"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/events","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.locations.events.list"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/groupStats","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groupStats)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.locations.groupStats.list"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.locations.groups.get"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/events:report","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events:report)$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.events.report"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.groups.update"},{"hostname":"clouderrorreporting.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.clouderrorreporting","resource_name":"clouderrorreporting.projects.locations.groups.update"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.delete"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/operations","path_regex":"^(?:/v1beta2/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/operations/{operationsId}","path_regex":"^(?:/v1beta2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.runtimes.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.runtimes.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:getIamPolicy","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.getIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.operations.get"},{"hostname":"cloudfunctions.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.runtimes.list"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.patch"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:call","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::call)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.call"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:call","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::call)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.call"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:abortFunctionUpgrade","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::abortFunctionUpgrade)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.abortFunctionUpgrade"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:commitFunctionUpgrade","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commitFunctionUpgrade)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.commitFunctionUpgrade"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:redirectFunctionUpgradeTraffic","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::redirectFunctionUpgradeTraffic)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.redirectFunctionUpgradeTraffic"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:rollbackFunctionUpgradeTraffic","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollbackFunctionUpgradeTraffic)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.rollbackFunctionUpgradeTraffic"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setupFunctionUpgradeConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setupFunctionUpgradeConfig)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setupFunctionUpgradeConfig"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:abortFunctionUpgrade","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::abortFunctionUpgrade)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.abortFunctionUpgrade"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:commitFunctionUpgrade","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commitFunctionUpgrade)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.commitFunctionUpgrade"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:redirectFunctionUpgradeTraffic","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::redirectFunctionUpgradeTraffic)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.redirectFunctionUpgradeTraffic"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:rollbackFunctionUpgradeTraffic","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollbackFunctionUpgradeTraffic)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.rollbackFunctionUpgradeTraffic"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setupFunctionUpgradeConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setupFunctionUpgradeConfig)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setupFunctionUpgradeConfig"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.create"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:abortFunctionUpgrade","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::abortFunctionUpgrade)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.abortFunctionUpgrade"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:commitFunctionUpgrade","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commitFunctionUpgrade)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.commitFunctionUpgrade"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:generateDownloadUrl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDownloadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateDownloadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:redirectFunctionUpgradeTraffic","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::redirectFunctionUpgradeTraffic)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.redirectFunctionUpgradeTraffic"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:rollbackFunctionUpgradeTraffic","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollbackFunctionUpgradeTraffic)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.rollbackFunctionUpgradeTraffic"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setIamPolicy","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setIamPolicy"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:setupFunctionUpgradeConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setupFunctionUpgradeConfig)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.setupFunctionUpgradeConfig"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}:testIamPermissions","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.testIamPermissions"},{"hostname":"cloudfunctions.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/functions:generateUploadUrl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions:generateUploadUrl)$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.generateUploadUrl"},{"hostname":"cloudfunctions.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/functions/{functionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/functions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudfunctions","resource_name":"cloudfunctions.projects.locations.functions.update"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/devices/{devicesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/groups/{groupsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/devices/{devicesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/groups/{groupsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1beta1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.delete"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/userinvitations","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}:isInvitableUser","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::isInvitableUser)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.isInvitableUser"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices","path_regex":"^(?:/v1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/devices/{devicesId}/deviceUsers:lookup","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups","path_regex":"^(?:/v1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:checkTransitiveMembership","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:checkTransitiveMembership)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.checkTransitiveMembership"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:getMembershipGraph","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:getMembershipGraph)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.getMembershipGraph"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:lookup","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:searchDirectGroups","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchDirectGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchDirectGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:searchTransitiveGroups","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/memberships:searchTransitiveMemberships","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveMemberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveMemberships"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.getSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups:lookup","path_regex":"^(?:/v1/groups:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/groups:search","path_regex":"^(?:/v1/groups:search)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.search"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles","path_regex":"^(?:/v1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSsoAssignments","path_regex":"^(?:/v1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/customers/{customersId}/userinvitations","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}:isInvitableUser","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::isInvitableUser)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.isInvitableUser"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices","path_regex":"^(?:/v1beta1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/devices/{devicesId}/deviceUsers:lookup","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups","path_regex":"^(?:/v1beta1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:checkTransitiveMembership","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:checkTransitiveMembership)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.checkTransitiveMembership"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:getMembershipGraph","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:getMembershipGraph)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.getMembershipGraph"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:lookup","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:searchDirectGroups","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchDirectGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchDirectGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:searchTransitiveGroups","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveGroups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveGroups"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/memberships:searchTransitiveMemberships","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:searchTransitiveMemberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.searchTransitiveMemberships"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.getSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups:lookup","path_regex":"^(?:/v1beta1/groups:lookup)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.lookup"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/groups:search","path_regex":"^(?:/v1beta1/groups:search)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.search"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials/{idpCredentialsId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSsoAssignments","path_regex":"^(?:/v1beta1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1beta1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.get"},{"hostname":"cloudidentity.googleapis.com","http_method":"GET","path_template":"/v1beta1/orgUnits/{orgUnitsId}/memberships","path_regex":"^(?:/v1beta1/orgUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.orgUnits.memberships.list"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/groups/{groupsId}","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.updateSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}/clientStates/{clientStatesId}","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.clientStates.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/groups/{groupsId}","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/groups/{groupsId}/securitySettings","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.updateSecuritySettings"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/inboundSsoAssignments/{inboundSsoAssignmentsId}","path_regex":"^(?:/v1beta1/inboundSsoAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.patch"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}:cancel","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.cancel"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/customers/{customersId}/userinvitations/{userinvitationsId}:send","path_regex":"^(?:/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::send)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.send"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices","path_regex":"^(?:/v1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:approve","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.approve"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:block","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::block)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.block"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:cancelWipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}/deviceUsers/{deviceUsersId}:wipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}:cancelWipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/devices/{devicesId}:wipe","path_regex":"^(?:/v1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/groups","path_regex":"^(?:/v1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/groups/{groupsId}/memberships","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/groups/{groupsId}/memberships/{membershipsId}:modifyMembershipRoles","path_regex":"^(?:/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyMembershipRoles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.modifyMembershipRoles"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/inboundSamlSsoProfiles","path_regex":"^(?:/v1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials:add","path_regex":"^(?:/v1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials:add)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.add"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1/inboundSsoAssignments","path_regex":"^(?:/v1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}:cancel","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.cancel"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/customers/{customersId}/userinvitations/{userinvitationsId}:send","path_regex":"^(?:/v1beta1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userinvitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::send)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.customers.userinvitations.send"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices","path_regex":"^(?:/v1beta1/devices)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:approve","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::approve)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.approve"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:block","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::block)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.block"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:cancelWipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}/deviceUsers/{deviceUsersId}:wipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.deviceUsers.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}:cancelWipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelWipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.cancelWipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/devices/{devicesId}:wipe","path_regex":"^(?:/v1beta1/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wipe)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.devices.wipe"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/groups","path_regex":"^(?:/v1beta1/groups)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/groups/{groupsId}/memberships","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/groups/{groupsId}/memberships/{membershipsId}:modifyMembershipRoles","path_regex":"^(?:/v1beta1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyMembershipRoles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.groups.memberships.modifyMembershipRoles"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/inboundSamlSsoProfiles","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/inboundSamlSsoProfiles/{inboundSamlSsoProfilesId}/idpCredentials:add","path_regex":"^(?:/v1beta1/inboundSamlSsoProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idpCredentials:add)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSamlSsoProfiles.idpCredentials.add"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/inboundSsoAssignments","path_regex":"^(?:/v1beta1/inboundSsoAssignments)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.inboundSsoAssignments.create"},{"hostname":"cloudidentity.googleapis.com","http_method":"POST","path_template":"/v1beta1/orgUnits/{orgUnitsId}/memberships/{membershipsId}:move","path_regex":"^(?:/v1beta1/orgUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudidentity","resource_name":"cloudidentity.orgUnits.memberships.move"},{"hostname":"cloudiot.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.delete"},{"hostname":"cloudiot.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.delete"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.get"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.get"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}/configVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configVersions)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.configVersions.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}/states","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/states)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.states.list"},{"hostname":"cloudiot.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}/devices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.devices.list"},{"hostname":"cloudiot.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.patch"},{"hostname":"cloudiot.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.patch"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.create"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.create"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}:modifyCloudToDeviceConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyCloudToDeviceConfig)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.modifyCloudToDeviceConfig"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/devices/{devicesId}:sendCommandToDevice","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sendCommandToDevice)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.devices.sendCommandToDevice"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.getIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.setIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}/groups/{groupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.groups.testIamPermissions"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:bindDeviceToGateway","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bindDeviceToGateway)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.bindDeviceToGateway"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.getIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.setIamPolicy"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.testIamPermissions"},{"hostname":"cloudiot.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registries/{registriesId}:unbindDeviceFromGateway","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unbindDeviceFromGateway)$","service_name":"google.cloudiot","resource_name":"cloudiot.projects.locations.registries.unbindDeviceFromGateway"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/autokeyConfig","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autokeyConfig)$","service_name":"google.cloudkms","resource_name":"cloudkms.folders.getAutokeyConfig"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.getEkmConfig"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig:getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConfig.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:verifyConnectivity","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verifyConnectivity)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.verifyConnectivity"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyHandles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyHandles)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyHandles.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyHandles/{keyHandlesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyHandles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyHandles.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}/publicKey","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicKey)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.getPublicKey"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.list"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.getIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.operations.get"},{"hostname":"cloudkms.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}:showEffectiveAutokeyConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::showEffectiveAutokeyConfig)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.showEffectiveAutokeyConfig"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/autokeyConfig","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autokeyConfig)$","service_name":"google.cloudkms","resource_name":"cloudkms.folders.updateAutokeyConfig"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.updateEkmConfig"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.patch"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.patch"},{"hostname":"cloudkms.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.patch"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig:setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConfig.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConfig:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConfig:testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConfig.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ekmConnections/{ekmConnectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ekmConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.ekmConnections.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyHandles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyHandles)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyHandles.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:asymmetricDecrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::asymmetricDecrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.asymmetricDecrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:asymmetricSign","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::asymmetricSign)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.asymmetricSign"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:destroy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.destroy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:macSign","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::macSign)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.macSign"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:macVerify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::macVerify)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.macVerify"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:rawDecrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rawDecrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.rawDecrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:rawEncrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rawEncrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.rawEncrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions/{cryptoKeyVersionsId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.restore"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/cryptoKeyVersions:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeyVersions:import)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.cryptoKeyVersions.import"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:decrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.decrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:encrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::encrypt)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.encrypt"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}:updatePrimaryVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updatePrimaryVersion)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.cryptoKeys.updatePrimaryVersion"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.create"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/importJobs/{importJobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.importJobs.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.setIamPolicy"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.keyRings.testIamPermissions"},{"hostname":"cloudkms.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:generateRandomBytes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateRandomBytes)$","service_name":"google.cloudkms","resource_name":"cloudkms.projects.locations.generateRandomBytes"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/catalogs:search","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.folders.catalogs.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/products:search","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.folders.products.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/versions:search","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.folders.versions.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/catalogs:search","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.organizations.catalogs.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/products:search","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.organizations.products.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/versions:search","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.organizations.versions.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/catalogs:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.projects.catalogs.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/products:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.projects.products.search"},{"hostname":"cloudprivatecatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/versions:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:search)$","service_name":"google.cloudprivatecatalog","resource_name":"cloudprivatecatalog.projects.versions.search"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}/associations/{associationsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.delete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs","path_regex":"^(?:/v1beta1/catalogs)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/associations","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/associations/{associationsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/catalogs/{catalogsId}:getIamPolicy","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.getIamPolicy"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.list"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.get"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.patch"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.patch"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.patch"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs","path_regex":"^(?:/v1beta1/catalogs)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/associations","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/associations)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.associations.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/icons:upload","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/icons:upload)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.icons.upload"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}/versions","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.versions.create"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}/products/{productsId}:copy","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::copy)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.products.copy"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}:setIamPolicy","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.setIamPolicy"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}:testIamPermissions","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.testIamPermissions"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalogs/{catalogsId}:undelete","path_regex":"^(?:/v1beta1/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.catalogs.undelete"},{"hostname":"cloudprivatecatalogproducer.googleapis.com","http_method":"POST","path_template":"/v1beta1/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudprivatecatalogproducer","resource_name":"cloudprivatecatalogproducer.operations.cancel"},{"hostname":"cloudprofiler.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/profiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.cloudprofiler","resource_name":"cloudprofiler.projects.profiles.list"},{"hostname":"cloudprofiler.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/profiles/{profilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudprofiler","resource_name":"cloudprofiler.projects.profiles.patch"},{"hostname":"cloudprofiler.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/profiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.cloudprofiler","resource_name":"cloudprofiler.projects.profiles.create"},{"hostname":"cloudprofiler.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/profiles:createOffline","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles:createOffline)$","service_name":"google.cloudprofiler","resource_name":"cloudprofiler.projects.profiles.createOffline"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/liens/{liensId}","path_regex":"^(?:/v1/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/folders/{foldersId}","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/liens/{liensId}","path_regex":"^(?:/v3/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagBindings/{tagBindingsId}","path_regex":"^(?:/v3/tagBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagBindings.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagKeys/{tagKeysId}","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagValues/{tagValuesId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"DELETE","path_template":"/v3/tagValues/{tagValuesId}/tagHolds/{tagHoldsId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagHolds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.tagHolds.delete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/liens","path_regex":"^(?:/v1/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/liens/{liensId}","path_regex":"^(?:/v1/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1/{+name}","path_regex":"^(?:/v1/)((?:(?:[\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e\\x21\\x23\\x24\\x26-\\x2c\\x2f\\x3a\\x3b\\x3d\\x3f\\x40\\x5b\\x5d]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations","path_regex":"^(?:/v1beta1/organizations)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects","path_regex":"^(?:/v1beta1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/effectiveTags","path_regex":"^(?:/v3/effectiveTags)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.effectiveTags.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/folders","path_regex":"^(?:/v3/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/folders/{foldersId}","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/folders:search","path_regex":"^(?:/v3/folders:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/liens","path_regex":"^(?:/v3/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/liens/{liensId}","path_regex":"^(?:/v3/liens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/operations/{operationsId}","path_regex":"^(?:/v3/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.operations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/organizations/{organizationsId}","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/organizations:search","path_regex":"^(?:/v3/organizations:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/projects","path_regex":"^(?:/v3/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/projects:search","path_regex":"^(?:/v3/projects:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagBindings","path_regex":"^(?:/v3/tagBindings)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagBindings.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagKeys","path_regex":"^(?:/v3/tagKeys)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagKeys/namespaced","path_regex":"^(?:/v3/tagKeys/namespaced)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.getNamespaced"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagKeys/{tagKeysId}","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues","path_regex":"^(?:/v3/tagValues)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues/namespaced","path_regex":"^(?:/v3/tagValues/namespaced)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.getNamespaced"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues/{tagValuesId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.get"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"GET","path_template":"/v3/tagValues/{tagValuesId}/tagHolds","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagHolds)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.tagHolds.list"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/folders/{foldersId}","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/tagKeys/{tagKeysId}","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PATCH","path_template":"/v3/tagValues/{tagValuesId}","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.patch"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:clearOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.clearOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:getEffectiveOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectiveOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getEffectiveOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:getOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:listAvailableOrgPolicyConstraints","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAvailableOrgPolicyConstraints)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.listAvailableOrgPolicyConstraints"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:listOrgPolicies","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listOrgPolicies)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.listOrgPolicies"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}:setOrgPolicy","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/liens","path_regex":"^(?:/v1/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:clearOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.clearOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getEffectiveOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectiveOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getEffectiveOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:getOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:listAvailableOrgPolicyConstraints","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAvailableOrgPolicyConstraints)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.listAvailableOrgPolicyConstraints"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:listOrgPolicies","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listOrgPolicies)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.listOrgPolicies"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:setOrgPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations:search","path_regex":"^(?:/v1/organizations:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/organizations:search","path_regex":"^(?:/v1/organizations:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:getAncestry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getAncestry)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getAncestry"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:clearOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.clearOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:getEffectiveOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectiveOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getEffectiveOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:getOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:listAvailableOrgPolicyConstraints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAvailableOrgPolicyConstraints)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.listAvailableOrgPolicyConstraints"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:listOrgPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listOrgPolicies)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.listOrgPolicies"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:setOrgPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setOrgPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setOrgPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{resource}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{resource}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{resource}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:getIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:setIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}:testIamPermissions","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects","path_regex":"^(?:/v1beta1/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:getAncestry","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getAncestry)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getAncestry"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{resource}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{resource}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{resource}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders","path_regex":"^(?:/v2/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:getIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:getIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:move","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:move","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:setIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:setIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:testIamPermissions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:testIamPermissions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:undelete","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}:undelete","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders:search","path_regex":"^(?:/v2/folders:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v2/folders:search","path_regex":"^(?:/v2/folders:search)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.search"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders","path_regex":"^(?:/v3/folders)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:getIamPolicy","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:move","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:setIamPolicy","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:testIamPermissions","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/folders/{foldersId}:undelete","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.folders.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/liens","path_regex":"^(?:/v3/liens)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.liens.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/organizations/{organizationsId}:getIamPolicy","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/organizations/{organizationsId}:setIamPolicy","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/organizations/{organizationsId}:testIamPermissions","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects","path_regex":"^(?:/v3/projects)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:getIamPolicy","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:move","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.move"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:setIamPolicy","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:testIamPermissions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:undelete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.undelete"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagBindings","path_regex":"^(?:/v3/tagBindings)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagBindings.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys","path_regex":"^(?:/v3/tagKeys)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys/{tagKeysId}:getIamPolicy","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys/{tagKeysId}:setIamPolicy","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagKeys/{tagKeysId}:testIamPermissions","path_regex":"^(?:/v3/tagKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagKeys.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues","path_regex":"^(?:/v3/tagValues)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}/tagHolds","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagHolds)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.tagHolds.create"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}:getIamPolicy","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.getIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}:setIamPolicy","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.setIamPolicy"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"POST","path_template":"/v3/tagValues/{tagValuesId}:testIamPermissions","path_regex":"^(?:/v3/tagValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.tagValues.testIamPermissions"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.update"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PUT","path_template":"/v1beta1/organizations/{organizationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.organizations.update"},{"hostname":"cloudresourcemanager.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudresourcemanager","resource_name":"cloudresourcemanager.projects.update"},{"hostname":"cloudscheduler.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.delete"},{"hostname":"cloudscheduler.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.delete"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.list"},{"hostname":"cloudscheduler.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.get"},{"hostname":"cloudscheduler.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.patch"},{"hostname":"cloudscheduler.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.patch"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.create"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:pause","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.pause"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.resume"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.run"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.create"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:pause","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.pause"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.resume"},{"hostname":"cloudscheduler.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:run","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudscheduler","resource_name":"cloudscheduler.projects.locations.jobs.run"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.delete"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/indexing/datasources/{datasourcesId}/schema","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schema)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.deleteSchema"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.delete"},{"hostname":"cloudsearch.googleapis.com","http_method":"DELETE","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.delete"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/debug/datasources/{datasourcesId}/items/{itemsId}/unmappedids","path_regex":"^(?:/v1/debug/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unmappedids)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.datasources.items.unmappedids.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/debug/identitysources/{identitysourcesId}/items:forunmappedidentity","path_regex":"^(?:/v1/debug/identitysources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:forunmappedidentity)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.identitysources.items.listForunmappedidentity"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/debug/identitysources/{identitysourcesId}/unmappedids","path_regex":"^(?:/v1/debug/identitysources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unmappedids)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.identitysources.unmappedids.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/indexing/datasources/{datasourcesId}/items","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/indexing/datasources/{datasourcesId}/schema","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schema)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.getSchema"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.operations.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}/lro","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lro)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.operations.lro.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/query/sources","path_regex":"^(?:/v1/query/sources)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.sources.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/customer","path_regex":"^(?:/v1/settings/customer)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.getCustomer"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/datasources","path_regex":"^(?:/v1/settings/datasources)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/searchapplications","path_regex":"^(?:/v1/settings/searchapplications)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.list"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/index","path_regex":"^(?:/v1/stats/index)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getIndex"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/index/datasources/{datasourcesId}","path_regex":"^(?:/v1/stats/index/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.index.datasources.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/query","path_regex":"^(?:/v1/stats/query)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getQuery"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/query/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/stats/query/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.query.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/searchapplication","path_regex":"^(?:/v1/stats/searchapplication)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getSearchapplication"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/session","path_regex":"^(?:/v1/stats/session)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getSession"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/session/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/stats/session/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.session.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/user","path_regex":"^(?:/v1/stats/user)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.getUser"},{"hostname":"cloudsearch.googleapis.com","http_method":"GET","path_template":"/v1/stats/user/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/stats/user/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.stats.user.searchapplications.get"},{"hostname":"cloudsearch.googleapis.com","http_method":"PATCH","path_template":"/v1/settings/customer","path_regex":"^(?:/v1/settings/customer)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.updateCustomer"},{"hostname":"cloudsearch.googleapis.com","http_method":"PATCH","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.patch"},{"hostname":"cloudsearch.googleapis.com","http_method":"PATCH","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.patch"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/debug/datasources/{datasourcesId}/items/{itemsId}:checkAccess","path_regex":"^(?:/v1/debug/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkAccess)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.datasources.items.checkAccess"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/debug/datasources/{datasourcesId}/items:searchByViewUrl","path_regex":"^(?:/v1/debug/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:searchByViewUrl)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.debug.datasources.items.searchByViewUrl"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}:index","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::index)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.index"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}:push","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::push)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.push"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items/{itemsId}:upload","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upload)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.upload"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items:deleteQueueItems","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:deleteQueueItems)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.deleteQueueItems"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items:poll","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:poll)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.poll"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/indexing/datasources/{datasourcesId}/items:unreserve","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/items:unreserve)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.items.unreserve"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.media.upload"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/query/search","path_regex":"^(?:/v1/query/search)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.search"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/query/suggest","path_regex":"^(?:/v1/query/suggest)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.suggest"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/query:debugSearch","path_regex":"^(?:/v1/query:debugSearch)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.debugSearch"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/query:removeActivity","path_regex":"^(?:/v1/query:removeActivity)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.query.removeActivity"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/settings/datasources","path_regex":"^(?:/v1/settings/datasources)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.create"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/settings/searchapplications","path_regex":"^(?:/v1/settings/searchapplications)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.create"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1/settings/searchapplications/{searchapplicationsId}:reset","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.reset"},{"hostname":"cloudsearch.googleapis.com","http_method":"POST","path_template":"/v1:initializeCustomer","path_regex":"^(?:/v1:initializeCustomer)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.initializeCustomer"},{"hostname":"cloudsearch.googleapis.com","http_method":"PUT","path_template":"/v1/indexing/datasources/{datasourcesId}/schema","path_regex":"^(?:/v1/indexing/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schema)$","service_name":"google.cloudsearch","resource_name":"cloudsearch.indexing.datasources.updateSchema"},{"hostname":"cloudsearch.googleapis.com","http_method":"PUT","path_template":"/v1/settings/datasources/{datasourcesId}","path_regex":"^(?:/v1/settings/datasources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.datasources.update"},{"hostname":"cloudsearch.googleapis.com","http_method":"PUT","path_template":"/v1/settings/searchapplications/{searchapplicationsId}","path_regex":"^(?:/v1/settings/searchapplications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsearch","resource_name":"cloudsearch.settings.searchapplications.update"},{"hostname":"cloudshell.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.delete"},{"hostname":"cloudshell.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}/publicKeys/{publicKeysId}","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.publicKeys.delete"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.list"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.get"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/environments/{environmentsId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.get"},{"hostname":"cloudshell.googleapis.com","http_method":"GET","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.get"},{"hostname":"cloudshell.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.patch"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.cloudshell","resource_name":"cloudshell.operations.cancel"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:addPublicKey","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addPublicKey)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.addPublicKey"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:authorize","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::authorize)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.authorize"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:removePublicKey","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removePublicKey)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.removePublicKey"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/environments/{environmentsId}:start","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.start"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}/publicKeys","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicKeys)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.publicKeys.create"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}:authorize","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::authorize)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.authorize"},{"hostname":"cloudshell.googleapis.com","http_method":"POST","path_template":"/v1alpha1/users/{usersId}/environments/{environmentsId}:start","path_regex":"^(?:/v1alpha1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.cloudshell","resource_name":"cloudshell.users.environments.start"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2/caseClassifications:search","path_regex":"^(?:/v2/caseClassifications:search)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.caseClassifications.search"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cases","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.get"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}/attachments","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.attachments.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}/attachments/{attachmentsId}:download","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.media.download"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}/comments","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.comments.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cases:search","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases:search)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.search"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/caseClassifications:search","path_regex":"^(?:/v2beta/caseClassifications:search)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.caseClassifications.search"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/cases:search","path_regex":"^(?:/v2beta/cases:search)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.search"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.get"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/attachments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.attachments.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/attachments/{attachmentsId}:download","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.media.download"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/comments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.comments.list"},{"hostname":"cloudsupport.googleapis.com","http_method":"GET","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}:showFeed","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::showFeed)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.showFeed"},{"hostname":"cloudsupport.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.patch"},{"hostname":"cloudsupport.googleapis.com","http_method":"PATCH","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.patch"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/cases","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.create"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}/attachments","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.media.upload"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}/comments","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.comments.create"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}:close","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.close"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/cases/{casesId}:escalate","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::escalate)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.escalate"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.create"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/attachments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.media.upload"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}/comments","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.comments.create"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}:close","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.close"},{"hostname":"cloudsupport.googleapis.com","http_method":"POST","path_template":"/v2beta/{v2betaId}/{v2betaId1}/cases/{casesId}:escalate","path_regex":"^(?:/v2beta/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::escalate)$","service_name":"google.cloudsupport","resource_name":"cloudsupport.cases.escalate"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"DELETE","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.delete"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/cmekConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekConfig)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.getCmekConfig"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/cmekConfig","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekConfig)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.getCmekConfig"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/cmekConfig","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekConfig)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.getCmekConfig"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.list"},{"hostname":"cloudtasks.googleapis.com","http_method":"GET","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.get"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/cmekConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekConfig)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.updateCmekConfig"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.patch"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/cmekConfig","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekConfig)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.updateCmekConfig"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.patch"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/cmekConfig","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekConfig)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.updateCmekConfig"},{"hostname":"cloudtasks.googleapis.com","http_method":"PATCH","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.patch"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/api/queue/update","path_regex":"^(?:/api/queue/update)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.api.queue.update"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{taskId}:buffer","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::buffer)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.buffer"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:run","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.run"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.getIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:pause","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.pause"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:purge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::purge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.purge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:resume","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.resume"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.setIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.testIamPermissions"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{taskId}:buffer","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::buffer)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.buffer"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:acknowledge","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.acknowledge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:cancelLease","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelLease)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.cancelLease"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:renewLease","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::renewLease)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.renewLease"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:run","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.run"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks:lease","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks:lease)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.lease"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:getIamPolicy","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.getIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:pause","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.pause"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:purge","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::purge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.purge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:resume","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.resume"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:setIamPolicy","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.setIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta2/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:testIamPermissions","path_regex":"^(?:/v2beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.testIamPermissions"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.create"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{taskId}:buffer","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::buffer)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.buffer"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}/tasks/{tasksId}:run","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.tasks.run"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:getIamPolicy","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.getIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:pause","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.pause"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:purge","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::purge)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.purge"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:resume","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.resume"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:setIamPolicy","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.setIamPolicy"},{"hostname":"cloudtasks.googleapis.com","http_method":"POST","path_template":"/v2beta3/projects/{projectsId}/locations/{locationsId}/queues/{queuesId}:testIamPermissions","path_regex":"^(?:/v2beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.cloudtasks","resource_name":"cloudtasks.projects.locations.queues.testIamPermissions"},{"hostname":"cloudtrace.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/traceSinks/{traceSinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.delete"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/traces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.list"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/traces/{traceId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.get"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/traceSinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.list"},{"hostname":"cloudtrace.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/traceSinks/{traceSinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.get"},{"hostname":"cloudtrace.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/traces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.patchTraces"},{"hostname":"cloudtrace.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/traceSinks/{traceSinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.patch"},{"hostname":"cloudtrace.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/traces/{tracesId}/spans/{spansId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.spans.createSpan"},{"hostname":"cloudtrace.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/traces:batchWrite","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces:batchWrite)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traces.batchWrite"},{"hostname":"cloudtrace.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/traceSinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traceSinks)$","service_name":"google.cloudtrace","resource_name":"cloudtrace.projects.traceSinks.create"},{"hostname":"commentanalyzer.googleapis.com","http_method":"POST","path_template":"/v1alpha1/comments:analyze","path_regex":"^(?:/v1alpha1/comments:analyze)$","service_name":"google.commentanalyzer","resource_name":"commentanalyzer.comments.analyze"},{"hostname":"commentanalyzer.googleapis.com","http_method":"POST","path_template":"/v1alpha1/comments:suggestscore","path_regex":"^(?:/v1alpha1/comments:suggestscore)$","service_name":"google.commentanalyzer","resource_name":"commentanalyzer.comments.suggestscore"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps/{userWorkloadsConfigMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets/{userWorkloadsSecretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps/{userWorkloadsConfigMapsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets/{userWorkloadsSecretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.delete"},{"hostname":"composer.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.delete"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps/{userWorkloadsConfigMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets/{userWorkloadsSecretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/workloads","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.workloads.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:fetchDatabaseProperties","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchDatabaseProperties)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.fetchDatabaseProperties"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageVersions)$","service_name":"google.composer","resource_name":"composer.projects.locations.imageVersions.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps/{userWorkloadsConfigMapsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets/{userWorkloadsSecretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.get"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/workloads","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.workloads.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:fetchDatabaseProperties","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchDatabaseProperties)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.fetchDatabaseProperties"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/imageVersions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageVersions)$","service_name":"google.composer","resource_name":"composer.projects.locations.imageVersions.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.list"},{"hostname":"composer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.operations.get"},{"hostname":"composer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.patch"},{"hostname":"composer.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.patch"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:checkUpgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkUpgrade)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.checkUpgrade"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:databaseFailover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::databaseFailover)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.databaseFailover"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:executeAirflowCommand","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeAirflowCommand)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.executeAirflowCommand"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:loadSnapshot","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::loadSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.loadSnapshot"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:pollAirflowCommand","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pollAirflowCommand)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.pollAirflowCommand"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:saveSnapshot","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::saveSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.saveSnapshot"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:stopAirflowCommand","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopAirflowCommand)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.stopAirflowCommand"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.create"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:checkUpgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkUpgrade)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.checkUpgrade"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:databaseFailover","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::databaseFailover)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.databaseFailover"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:executeAirflowCommand","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeAirflowCommand)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.executeAirflowCommand"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:loadSnapshot","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::loadSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.loadSnapshot"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:pollAirflowCommand","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pollAirflowCommand)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.pollAirflowCommand"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:restartWebServer","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restartWebServer)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.restartWebServer"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:saveSnapshot","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::saveSnapshot)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.saveSnapshot"},{"hostname":"composer.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}:stopAirflowCommand","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopAirflowCommand)$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.stopAirflowCommand"},{"hostname":"composer.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps/{userWorkloadsConfigMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.update"},{"hostname":"composer.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets/{userWorkloadsSecretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.update"},{"hostname":"composer.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsConfigMaps/{userWorkloadsConfigMapsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsConfigMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsConfigMaps.update"},{"hostname":"composer.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}/userWorkloadsSecrets/{userWorkloadsSecretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userWorkloadsSecrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.composer","resource_name":"composer.projects.locations.environments.userWorkloadsSecrets.update"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/locations/global/operations/{operation}","path_regex":"^(?:/compute/alpha/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshotGroups/{instantSnapshotGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshotGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/multiMigs/{multiMig}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/multiMigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionMultiMigs.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots/{snapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshotGroups/{instantSnapshotGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshotGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources/{queuedResource}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/locations/global/operations/{operation}","path_regex":"^(?:/compute/beta/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/locations/global/operations/{operation}","path_regex":"^(?:/compute/v1/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.delete"},{"hostname":"compute.googleapis.com","http_method":"DELETE","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.delete"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/listAssociations","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/getPacketMirroringRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/operations","path_regex":"^(?:/compute/alpha/locations/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/operations/{operation}","path_regex":"^(?:/compute/alpha/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/listAssociations","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.projects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/acceleratorTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/commitments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/diskTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/disks)$","service_name":"google.compute","resource_name":"compute.disks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/futureReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/healthCheckServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instances)$","service_name":"google.compute","resource_name":"compute.instances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/interconnectAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/machineTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/networkAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/networkEdgeSecurityServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/nodeGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/nodeTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/nodeTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/notificationEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/packetMirrorings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/queuedResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/queuedResources)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/reservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/resourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/routers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/routers)$","service_name":"google.compute","resource_name":"compute.routers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/serviceAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/snapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/storagePoolTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/storagePoolTypes)$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/storagePools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/subnetworks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/subnetworks/listUsable","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks/listUsable)$","service_name":"google.compute","resource_name":"compute.subnetworks.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/targetVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/vpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/aggregated/vpnTunnels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/getXpnHost","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.getXpnHost"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/getXpnResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnResources)$","service_name":"google.compute","resource_name":"compute.projects.getXpnResources"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/addresses/getOwnerInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/getOwnerInstance)$","service_name":"google.compute","resource_name":"compute.globalAddresses.getOwnerInstance"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/listUsable","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/listUsable)$","service_name":"google.compute","resource_name":"compute.backendBuckets.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendServices/listUsable","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/listUsable)$","service_name":"google.compute","resource_name":"compute.backendServices.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/getPacketMirroringRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images/family/{family}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/family/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.getFromFamily"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectLocations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectLocations/{interconnectLocation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectRemoteLocations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations)$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnectRemoteLocations/{interconnectRemoteLocation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}/getDiagnostics","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiagnostics)$","service_name":"google.compute","resource_name":"compute.interconnects.getDiagnostics"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}/getMacsecConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getMacsecConfig)$","service_name":"google.compute","resource_name":"compute.interconnects.getMacsecConfig"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnects.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{licenseCode}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenseCodes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenseCodes.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/licenses/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/machineImages","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/machineImages/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkPlacements","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkPlacements)$","service_name":"google.compute","resource_name":"compute.networkPlacements.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkPlacements/{networkPlacement}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkPlacements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkPlacements.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkProfiles","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkProfiles)$","service_name":"google.compute","resource_name":"compute.networkProfiles.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networkProfiles/{networkProfile}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkProfiles.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/getEffectiveFirewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.networks.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/listIpAddresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listIpAddresses)$","service_name":"google.compute","resource_name":"compute.networks.listIpAddresses"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/listIpOwners","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listIpOwners)$","service_name":"google.compute","resource_name":"compute.networks.listIpOwners"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/listPeeringRoutes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPeeringRoutes)$","service_name":"google.compute","resource_name":"compute.networks.listPeeringRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/routes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/listPreconfiguredExpressionSets","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/listPreconfiguredExpressionSets)$","service_name":"google.compute","resource_name":"compute.securityPolicies.listPreconfiguredExpressionSets"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/snapshotSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.snapshotSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/snapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.sslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.compute","resource_name":"compute.regions.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regions.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/listUsable","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/listUsable)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/diskSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskSettings)$","service_name":"google.compute","resource_name":"compute.regionDiskSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/diskTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/diskTypes/{diskType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/getEffectiveFirewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagerResizeRequests.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshotGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshotGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshotGroups/{instantSnapshotGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshotGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/multiMigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/multiMigs)$","service_name":"google.compute","resource_name":"compute.regionMultiMigs.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/multiMigs/{multiMig}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/multiMigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionMultiMigs.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.regionOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/getNamedSet","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNamedSet)$","service_name":"google.compute","resource_name":"compute.routers.getNamedSet"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/getNatIpInfo","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatIpInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatIpInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/getNatMappingInfo","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatMappingInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatMappingInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/getRoutePolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRoutePolicy)$","service_name":"google.compute","resource_name":"compute.routers.getRoutePolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/getRouterStatus","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRouterStatus)$","service_name":"google.compute","resource_name":"compute.routers.getRouterStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/listBgpRoutes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listBgpRoutes)$","service_name":"google.compute","resource_name":"compute.routers.listBgpRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/listNamedSets","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNamedSets)$","service_name":"google.compute","resource_name":"compute.routers.listNamedSets"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/listRoutePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listRoutePolicies)$","service_name":"google.compute","resource_name":"compute.routers.listRoutePolicies"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshotSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.regionSnapshotSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.compute","resource_name":"compute.regionSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots/{snapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}/getStatus","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getStatus)$","service_name":"google.compute","resource_name":"compute.vpnGateways.getStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/regions/{region}/zones","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.regionZones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.zones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zones.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/acceleratorTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/acceleratorTypes/{acceleratorType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/diskSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskSettings)$","service_name":"google.compute","resource_name":"compute.diskSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/diskTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/diskTypes/{diskType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.diskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/imageFamilyViews/{family}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageFamilyViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.imageFamilyViews.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getEffectiveFirewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.instances.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getGuestAttributes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getGuestAttributes)$","service_name":"google.compute","resource_name":"compute.instances.getGuestAttributes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getPartnerMetadata","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getPartnerMetadata)$","service_name":"google.compute","resource_name":"compute.instances.getPartnerMetadata"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getShieldedInstanceIdentity","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedInstanceIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedInstanceIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/getShieldedVmIdentity","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedVmIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedVmIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/referrers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referrers)$","service_name":"google.compute","resource_name":"compute.instances.listReferrers"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/screenshot","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/screenshot)$","service_name":"google.compute","resource_name":"compute.instances.getScreenshot"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/serialPort","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serialPort)$","service_name":"google.compute","resource_name":"compute.instances.getSerialPortOutput"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshotGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups)$","service_name":"google.compute","resource_name":"compute.instantSnapshotGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshotGroups/{instantSnapshotGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshotGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/machineTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/machineTypes/{machineType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeTypes/{nodeType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.zoneOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources/{queuedResource}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePoolTypes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePoolTypes)$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePoolTypes/{storagePoolType}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePoolTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/getIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{storagePool}/listDisks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listDisks)$","service_name":"google.compute","resource_name":"compute.storagePools.listDisks"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/listAssociations","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/getPacketMirroringRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/operations","path_regex":"^(?:/compute/beta/locations/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/operations/{operation}","path_regex":"^(?:/compute/beta/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies","path_regex":"^(?:/compute/beta/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/listAssociations","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/getAssociation","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.projects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/acceleratorTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/commitments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/diskTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/disks)$","service_name":"google.compute","resource_name":"compute.disks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/futureReservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instances)$","service_name":"google.compute","resource_name":"compute.instances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/instantSnapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/interconnectAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/machineTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/networkAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/networkEdgeSecurityServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/nodeGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/nodeTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/nodeTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/packetMirrorings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/reservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/resourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/routers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/routers)$","service_name":"google.compute","resource_name":"compute.routers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/serviceAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/storagePoolTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/storagePoolTypes)$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/storagePools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/subnetworks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/subnetworks/listUsable","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks/listUsable)$","service_name":"google.compute","resource_name":"compute.subnetworks.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/targetVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/vpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/aggregated/vpnTunnels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/getXpnHost","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.getXpnHost"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/getXpnResources","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnResources)$","service_name":"google.compute","resource_name":"compute.projects.getXpnResources"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendServices/listUsable","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/listUsable)$","service_name":"google.compute","resource_name":"compute.backendServices.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/getPacketMirroringRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images/family/{family}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/family/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.getFromFamily"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/images/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnectLocations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnectLocations/{interconnectLocation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnectRemoteLocations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations)$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnectRemoteLocations/{interconnectRemoteLocation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnects","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}/getDiagnostics","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiagnostics)$","service_name":"google.compute","resource_name":"compute.interconnects.getDiagnostics"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}/getMacsecConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getMacsecConfig)$","service_name":"google.compute","resource_name":"compute.interconnects.getMacsecConfig"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenseCodes/{licenseCode}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenseCodes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/licenses/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/machineImages","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/machineImages/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks/{network}/getEffectiveFirewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.networks.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/networks/{network}/listPeeringRoutes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPeeringRoutes)$","service_name":"google.compute","resource_name":"compute.networks.listPeeringRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/routes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies/listPreconfiguredExpressionSets","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/listPreconfiguredExpressionSets)$","service_name":"google.compute","resource_name":"compute.securityPolicies.listPreconfiguredExpressionSets"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/snapshotSettings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.snapshotSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/snapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.sslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.compute","resource_name":"compute.regions.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regions.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/listUsable","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/listUsable)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/diskTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/diskTypes/{diskType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/getEffectiveFirewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.regionOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/getNatIpInfo","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatIpInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatIpInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/getNatMappingInfo","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatMappingInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatMappingInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/getRoutePolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRoutePolicy)$","service_name":"google.compute","resource_name":"compute.routers.getRoutePolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/getRouterStatus","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRouterStatus)$","service_name":"google.compute","resource_name":"compute.routers.getRouterStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/listBgpRoutes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listBgpRoutes)$","service_name":"google.compute","resource_name":"compute.routers.listBgpRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/listRoutePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listRoutePolicies)$","service_name":"google.compute","resource_name":"compute.routers.listRoutePolicies"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}/getStatus","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getStatus)$","service_name":"google.compute","resource_name":"compute.vpnGateways.getStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/regions/{region}/zones","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.regionZones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.zones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zones.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/acceleratorTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/acceleratorTypes/{acceleratorType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/diskTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/diskTypes/{diskType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.diskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/imageFamilyViews/{family}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageFamilyViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.imageFamilyViews.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getEffectiveFirewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.instances.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getGuestAttributes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getGuestAttributes)$","service_name":"google.compute","resource_name":"compute.instances.getGuestAttributes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getPartnerMetadata","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getPartnerMetadata)$","service_name":"google.compute","resource_name":"compute.instances.getPartnerMetadata"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getShieldedInstanceIdentity","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedInstanceIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedInstanceIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/getShieldedVmIdentity","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedVmIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedVmIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/referrers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referrers)$","service_name":"google.compute","resource_name":"compute.instances.listReferrers"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/screenshot","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/screenshot)$","service_name":"google.compute","resource_name":"compute.instances.getScreenshot"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/serialPort","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serialPort)$","service_name":"google.compute","resource_name":"compute.instances.getSerialPortOutput"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/machineTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/machineTypes/{machineType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeTypes/{nodeType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.zoneOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePoolTypes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePoolTypes)$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePoolTypes/{storagePoolType}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePoolTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools/{resource}/getIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools/{storagePool}/listDisks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listDisks)$","service_name":"google.compute","resource_name":"compute.storagePools.listDisks"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/listAssociations","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/listAssociations)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.listAssociations"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/operations","path_regex":"^(?:/compute/v1/locations/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/locations/global/operations/{operation}","path_regex":"^(?:/compute/v1/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOrganizationOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.projects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/acceleratorTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/commitments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/diskTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/disks)$","service_name":"google.compute","resource_name":"compute.disks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/futureReservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instances)$","service_name":"google.compute","resource_name":"compute.instances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/instantSnapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/interconnectAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/machineTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/networkAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/networkEdgeSecurityServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/nodeGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/nodeTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/nodeTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/packetMirrorings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/reservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/resourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/routers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/routers)$","service_name":"google.compute","resource_name":"compute.routers.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/serviceAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/storagePoolTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/storagePoolTypes)$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/storagePools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/subnetworks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/subnetworks/listUsable","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/subnetworks/listUsable)$","service_name":"google.compute","resource_name":"compute.subnetworks.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/targetVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/vpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/aggregated/vpnTunnels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.aggregatedList"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/getXpnHost","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.getXpnHost"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/getXpnResources","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getXpnResources)$","service_name":"google.compute","resource_name":"compute.projects.getXpnResources"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalAddresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendServices/listUsable","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/listUsable)$","service_name":"google.compute","resource_name":"compute.backendServices.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{externalVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images/family/{family}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/family/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.getFromFamily"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/images/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnectLocations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnectLocations/{interconnectLocation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnectRemoteLocations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations)$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnectRemoteLocations/{interconnectRemoteLocation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnects","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}/getDiagnostics","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiagnostics)$","service_name":"google.compute","resource_name":"compute.interconnects.getDiagnostics"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}/getMacsecConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getMacsecConfig)$","service_name":"google.compute","resource_name":"compute.interconnects.getMacsecConfig"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenseCodes/{licenseCode}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenseCodes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenses/{license}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.licenses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/licenses/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/machineImages","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/machineImages/{machineImage}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineImages.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/machineImages/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks/{network}/getEffectiveFirewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.networks.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/networks/{network}/listPeeringRoutes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPeeringRoutes)$","service_name":"google.compute","resource_name":"compute.networks.listPeeringRoutes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.compute","resource_name":"compute.globalOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/routes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/routes/{route}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies/listPreconfiguredExpressionSets","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/listPreconfiguredExpressionSets)$","service_name":"google.compute","resource_name":"compute.securityPolicies.listPreconfiguredExpressionSets"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/snapshotSettings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.snapshotSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/snapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/snapshots/{snapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.snapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.sslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetSslProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.compute","resource_name":"compute.regions.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regions.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{address}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.addresses.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/listUsable","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/listUsable)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.listUsable"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/diskTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/diskTypes/{diskType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDiskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/getEffectiveFirewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getAssociation"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/getRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates/{instanceTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{nodeTemplate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTemplates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints/{notificationEndpoint}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.regionOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}/getNatIpInfo","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatIpInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatIpInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}/getNatMappingInfo","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getNatMappingInfo)$","service_name":"google.compute","resource_name":"compute.routers.getNatMappingInfo"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}/getRouterStatus","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRouterStatus)$","service_name":"google.compute","resource_name":"compute.routers.getRouterStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/getRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.getRule"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates/{sslCertificate}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/listAvailableFeatures","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/listAvailableFeatures)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.listAvailableFeatures"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetPools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies/{targetTcpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways/{targetVpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnGateways.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{vpnGateway}/getStatus","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getStatus)$","service_name":"google.compute","resource_name":"compute.vpnGateways.getStatus"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels/{vpnTunnel}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.vpnTunnels.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/regions/{region}/zones","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.regionZones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.compute","resource_name":"compute.zones.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zones.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/acceleratorTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/acceleratorTypes/{acceleratorType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.acceleratorTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers/{autoscaler}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.autoscalers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/diskTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes)$","service_name":"google.compute","resource_name":"compute.diskTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/diskTypes/{diskType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.diskTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/imageFamilyViews/{family}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageFamilyViews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.imageFamilyViews.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listErrors","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listErrors)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listErrors"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/getEffectiveFirewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getEffectiveFirewalls)$","service_name":"google.compute","resource_name":"compute.instances.getEffectiveFirewalls"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/getGuestAttributes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getGuestAttributes)$","service_name":"google.compute","resource_name":"compute.instances.getGuestAttributes"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/getShieldedInstanceIdentity","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getShieldedInstanceIdentity)$","service_name":"google.compute","resource_name":"compute.instances.getShieldedInstanceIdentity"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/referrers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referrers)$","service_name":"google.compute","resource_name":"compute.instances.listReferrers"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/screenshot","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/screenshot)$","service_name":"google.compute","resource_name":"compute.instances.getScreenshot"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/serialPort","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serialPort)$","service_name":"google.compute","resource_name":"compute.instances.getSerialPortOutput"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots/{instantSnapshot}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instantSnapshots.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/machineTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes)$","service_name":"google.compute","resource_name":"compute.machineTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/machineTypes/{machineType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/machineTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.machineTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes)$","service_name":"google.compute","resource_name":"compute.nodeTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeTypes/{nodeType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.compute","resource_name":"compute.zoneOperations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.zoneOperations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePoolTypes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePoolTypes)$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePoolTypes/{storagePoolType}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePoolTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePoolTypes.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools/{resource}/getIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.getIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.get"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools/{storagePool}/listDisks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listDisks)$","service_name":"google.compute","resource_name":"compute.storagePools.listDisks"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.list"},{"hostname":"compute.googleapis.com","http_method":"GET","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances/{targetInstance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetInstances.get"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/updatePeering","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePeering)$","service_name":"google.compute","resource_name":"compute.networks.updatePeering"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/snapshotSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.snapshotSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/diskSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskSettings)$","service_name":"google.compute","resource_name":"compute.regionDiskSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshotSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.regionSnapshotSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/diskSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskSettings)$","service_name":"google.compute","resource_name":"compute.diskSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setShieldedInstanceIntegrityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedInstanceIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedInstanceIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setShieldedVmIntegrityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedVmIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedVmIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateDisplayDevice","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateDisplayDevice)$","service_name":"google.compute","resource_name":"compute.instances.updateDisplayDevice"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateNetworkInterface","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.updateNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedInstanceConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedInstanceConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedInstanceConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedVmConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedVmConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedVmConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/networks/{network}/updatePeering","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePeering)$","service_name":"google.compute","resource_name":"compute.networks.updatePeering"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/snapshotSettings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.snapshotSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setShieldedInstanceIntegrityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedInstanceIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedInstanceIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setShieldedVmIntegrityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedVmIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedVmIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateDisplayDevice","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateDisplayDevice)$","service_name":"google.compute","resource_name":"compute.instances.updateDisplayDevice"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateNetworkInterface","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.updateNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedInstanceConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedInstanceConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedInstanceConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedVmConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedVmConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedVmConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/images/{image}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.images.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/interconnects/{interconnect}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnects.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/networks/{network}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/networks/{network}/updatePeering","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePeering)$","service_name":"google.compute","resource_name":"compute.networks.updatePeering"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.securityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/snapshotSettings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshotSettings)$","service_name":"google.compute","resource_name":"compute.snapshotSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.sslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies/{targetGrpcProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies/{targetHttpProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments/{commitment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionCommitments.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionDisks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.forwardingRules.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices/{healthCheckService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{interconnectAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{networkAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices/{networkEdgeSecurityService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{packetMirroring}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.packetMirrorings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resourcePolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.resourcePolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{serviceAttachment}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.serviceAttachments.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies/{sslPolicy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.subnetworks.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.disks.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/futureReservations/{futureReservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.futureReservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceSettings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceSettings)$","service_name":"google.compute","resource_name":"compute.instanceSettings.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setShieldedInstanceIntegrityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setShieldedInstanceIntegrityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setShieldedInstanceIntegrityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateDisplayDevice","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateDisplayDevice)$","service_name":"google.compute","resource_name":"compute.instances.updateDisplayDevice"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateNetworkInterface","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.updateNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateShieldedInstanceConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShieldedInstanceConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateShieldedInstanceConfig"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.nodeGroups.patch"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.reservations.update"},{"hostname":"compute.googleapis.com","http_method":"PATCH","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools/{storagePool}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.storagePools.update"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/addPacketMirroringRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/move","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/patchPacketMirroringRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/removePacketMirroringRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removePacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/copyRules","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyRules)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.copyRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/move","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/locations/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/alpha/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/disableXpnHost","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/disableXpnResource","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/enableXpnHost","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/enableXpnResource","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses/{address}/move","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.globalAddresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalAddresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalAddresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}/addSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}/deleteSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendBuckets.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/addSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/deleteSignedUrlKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.backendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/externalVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/addPacketMirroringRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchPacketMirroringRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/removePacketMirroringRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removePacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewalls","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/firewalls/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewalls.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.healthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{image}/deprecate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deprecate)$","service_name":"google.compute","resource_name":"compute.images.deprecate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.images.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/images/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.images.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/instanceTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnectLocations/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectLocations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnectRemoteLocations/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnectRemoteLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectRemoteLocations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnects.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnects.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/interconnects/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnects.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenseCodes.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenseCodes/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenseCodes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenses/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/licenses/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/machineImages","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/machineImages/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/machineImages/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.machineImages.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/addPeering","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPeering)$","service_name":"google.compute","resource_name":"compute.networks.addPeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/removePeering","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePeering)$","service_name":"google.compute","resource_name":"compute.networks.removePeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{network}/switchToCustomMode","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchToCustomMode)$","service_name":"google.compute","resource_name":"compute.networks.switchToCustomMode"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/networks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/operations/{operation}/wait","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.globalOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/announce","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/withdraw","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/routes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/routes/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.securityPolicies.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.securityPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.snapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/snapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.snapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetGrpcProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setCertificateMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setQuicOverride","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setQuicOverride)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setQuicOverride"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setSslPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setBackendService","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setCertificateMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setProxyHeader","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setBackendService","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setProxyHeader","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.urlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.urlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.urlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/listXpnHosts","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listXpnHosts)$","service_name":"google.compute","resource_name":"compute.projects.listXpnHosts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/moveDisk","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveDisk)$","service_name":"google.compute","resource_name":"compute.projects.moveDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/moveInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveInstance)$","service_name":"google.compute","resource_name":"compute.projects.moveInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{address}/move","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.addresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.addresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.addresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}/calculateCancellationFee","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/calculateCancellationFee)$","service_name":"google.compute","resource_name":"compute.regionCommitments.calculateCancellationFee"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}/cancel","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.regionCommitments.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{commitment}/updateReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateReservations)$","service_name":"google.compute","resource_name":"compute.regionCommitments.updateReservations"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/commitments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionCommitments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionDisks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.regionDisks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionDisks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionDisks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionDisks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.forwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthCheckServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagerResizeRequests.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resumeInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resumeInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resumeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/startInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.startInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/stopInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.stopInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/suspendInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspendInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.suspendInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instances/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionInstances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshotGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshotGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/interconnectAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/multiMigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/multiMigs)$","service_name":"google.compute","resource_name":"compute.regionMultiMigs.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEdgeSecurityServices","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/nodeTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/notificationEndpoints/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/operations/{operation}/wait","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.regionOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/packetMirrorings/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/announce","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/withdraw","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/resourcePolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/deleteNamedSet","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNamedSet)$","service_name":"google.compute","resource_name":"compute.routers.deleteNamedSet"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/deleteRoutePolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteRoutePolicy)$","service_name":"google.compute","resource_name":"compute.routers.deleteRoutePolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/patchNamedSet","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchNamedSet)$","service_name":"google.compute","resource_name":"compute.routers.patchNamedSet"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/patchRoutePolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRoutePolicy)$","service_name":"google.compute","resource_name":"compute.routers.patchRoutePolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/preview","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preview)$","service_name":"google.compute","resource_name":"compute.routers.preview"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/updateNamedSet","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateNamedSet)$","service_name":"google.compute","resource_name":"compute.routers.updateNamedSet"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}/updateRoutePolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateRoutePolicy)$","service_name":"google.compute","resource_name":"compute.routers.updateRoutePolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/serviceAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.compute","resource_name":"compute.regionSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/snapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.subnetworks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}/expandIpCidrRange","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandIpCidrRange)$","service_name":"google.compute","resource_name":"compute.subnetworks.expandIpCidrRange"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/subnetworks/{subnetwork}/setPrivateIpGoogleAccess","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPrivateIpGoogleAccess)$","service_name":"google.compute","resource_name":"compute.subnetworks.setPrivateIpGoogleAccess"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetPools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/addHealthCheck","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.addHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/addInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.addInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/getHealth","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.targetPools.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/removeHealthCheck","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.removeHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/removeInstance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.removeInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/setBackup","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackup)$","service_name":"google.compute","resource_name":"compute.targetPools.setBackup"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetPools/{targetPool}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetPools.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/targetVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/regions/{region}/vpnTunnels/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setCloudArmorTier","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCloudArmorTier)$","service_name":"google.compute","resource_name":"compute.projects.setCloudArmorTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setCommonInstanceMetadata","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCommonInstanceMetadata)$","service_name":"google.compute","resource_name":"compute.projects.setCommonInstanceMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setDefaultNetworkTier","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultNetworkTier)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultNetworkTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setDefaultServiceAccount","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultServiceAccount)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setManagedProtectionTier","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setManagedProtectionTier)$","service_name":"google.compute","resource_name":"compute.projects.setManagedProtectionTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/setUsageExportBucket","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUsageExportBucket)$","service_name":"google.compute","resource_name":"compute.projects.setUsageExportBucket"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.autoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.disks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.disks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.disks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.disks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.disks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/futureReservations/{futureReservation}/cancel","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.futureReservations.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}/cancel","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resumeInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resumeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resumeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/startInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.startInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/stopInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.stopInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/suspendInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspendInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.suspendInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/addInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.addInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/removeInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.removeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.instanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/bulkInsert","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.instances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/addAccessConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.addAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/addNetworkInterface","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.addNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/addResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/attachDisk","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachDisk)$","service_name":"google.compute","resource_name":"compute.instances.attachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/deleteAccessConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.deleteAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/deleteNetworkInterface","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNetworkInterface)$","service_name":"google.compute","resource_name":"compute.instances.deleteNetworkInterface"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/detachDisk","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachDisk)$","service_name":"google.compute","resource_name":"compute.instances.detachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/patchPartnerMetadata","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPartnerMetadata)$","service_name":"google.compute","resource_name":"compute.instances.patchPartnerMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/performMaintenance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.instances.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/removeResourcePolicies","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/reset","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.compute","resource_name":"compute.instances.reset"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/resume","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.compute","resource_name":"compute.instances.resume"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/sendDiagnosticInterrupt","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendDiagnosticInterrupt)$","service_name":"google.compute","resource_name":"compute.instances.sendDiagnosticInterrupt"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setDiskAutoDelete","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDiskAutoDelete)$","service_name":"google.compute","resource_name":"compute.instances.setDiskAutoDelete"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instances.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMachineResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineResources)$","service_name":"google.compute","resource_name":"compute.instances.setMachineResources"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMachineType","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineType)$","service_name":"google.compute","resource_name":"compute.instances.setMachineType"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMetadata","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMetadata)$","service_name":"google.compute","resource_name":"compute.instances.setMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setMinCpuPlatform","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMinCpuPlatform)$","service_name":"google.compute","resource_name":"compute.instances.setMinCpuPlatform"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setName","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setName)$","service_name":"google.compute","resource_name":"compute.instances.setName"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setScheduling","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setScheduling)$","service_name":"google.compute","resource_name":"compute.instances.setScheduling"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setServiceAccount","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setServiceAccount)$","service_name":"google.compute","resource_name":"compute.instances.setServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/setTags","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTags)$","service_name":"google.compute","resource_name":"compute.instances.setTags"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/simulateMaintenanceEvent","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.instances.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/start","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.compute","resource_name":"compute.instances.start"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/startWithEncryptionKey","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startWithEncryptionKey)$","service_name":"google.compute","resource_name":"compute.instances.startWithEncryptionKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/stop","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.compute","resource_name":"compute.instances.stop"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/suspend","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.compute","resource_name":"compute.instances.suspend"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}/updateAccessConfig","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/setDeletionProtection","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDeletionProtection)$","service_name":"google.compute","resource_name":"compute.instances.setDeletionProtection"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshotGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshotGroups)$","service_name":"google.compute","resource_name":"compute.instantSnapshotGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/networkEndpointGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/addNodes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.addNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/deleteNodes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.deleteNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/listNodes","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.listNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/performMaintenance","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.nodeGroups.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/setNodeTemplate","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNodeTemplate)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setNodeTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/simulateMaintenanceEvent","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.nodeGroups.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/nodeGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/operations/{operation}/wait","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.zoneOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/queuedResources/{queuedResource}/cancel","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.zoneQueuedResources.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{reservation}/resize","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.reservations.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/reservations/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.reservations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/setIamPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/setLabels","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.storagePools.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/storagePools/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.storagePools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{resource}/testIamPermissions","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetInstances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/alpha/projects/{project}/zones/{zone}/targetInstances/{targetInstance}/setSecurityPolicy","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetInstances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/addPacketMirroringRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/move","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/patchPacketMirroringRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/removePacketMirroringRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removePacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies","path_regex":"^(?:/compute/beta/locations/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/addAssociation","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/copyRules","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyRules)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.copyRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/move","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/locations/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/beta/locations/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.organizationSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/disableXpnHost","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/disableXpnResource","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/enableXpnHost","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/enableXpnResource","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses/{address}/move","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.globalAddresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalAddresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalAddresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}/addSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}/deleteSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendBuckets.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/addSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/deleteSignedUrlKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.backendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/externalVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/addPacketMirroringRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchPacketMirroringRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchPacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/removePacketMirroringRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePacketMirroringRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removePacketMirroringRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewalls","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/firewalls/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewalls.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.healthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{image}/deprecate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deprecate)$","service_name":"google.compute","resource_name":"compute.images.deprecate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.images.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/images/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.images.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/instanceTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/interconnects","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/interconnects/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnects.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/interconnects/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnects.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenseCodes/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenseCodes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenses/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/licenses/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/machineImages","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/machineImages/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/machineImages/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.machineImages.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{network}/addPeering","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPeering)$","service_name":"google.compute","resource_name":"compute.networks.addPeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{network}/removePeering","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePeering)$","service_name":"google.compute","resource_name":"compute.networks.removePeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{network}/switchToCustomMode","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchToCustomMode)$","service_name":"google.compute","resource_name":"compute.networks.switchToCustomMode"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/networks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/operations/{operation}/wait","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.globalOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/announce","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/withdraw","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/routes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/routes/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.securityPolicies.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.securityPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.snapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/snapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.snapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.sslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetGrpcProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setCertificateMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setQuicOverride","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setQuicOverride)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setQuicOverride"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setSslPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setBackendService","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setCertificateMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setProxyHeader","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setBackendService","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setProxyHeader","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.urlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.urlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.urlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/listXpnHosts","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listXpnHosts)$","service_name":"google.compute","resource_name":"compute.projects.listXpnHosts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/moveDisk","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveDisk)$","service_name":"google.compute","resource_name":"compute.projects.moveDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/moveInstance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveInstance)$","service_name":"google.compute","resource_name":"compute.projects.moveInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{address}/move","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.addresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.addresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/addresses/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.addresses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{commitment}/updateReservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateReservations)$","service_name":"google.compute","resource_name":"compute.regionCommitments.updateReservations"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/commitments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionCommitments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionDisks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.regionDisks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionDisks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionDisks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionDisks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/forwardingRules/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.forwardingRules.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthCheckServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resumeInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resumeInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resumeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/startInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.startInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/stopInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.stopInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/suspendInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspendInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.suspendInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instances/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionInstances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/interconnectAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEdgeSecurityServices","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/nodeTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/notificationEndpoints/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/operations/{operation}/wait","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.regionOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/packetMirrorings/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/announce","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/withdraw","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/resourcePolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.routers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/deleteRoutePolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteRoutePolicy)$","service_name":"google.compute","resource_name":"compute.routers.deleteRoutePolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/preview","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preview)$","service_name":"google.compute","resource_name":"compute.routers.preview"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}/updateRoutePolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateRoutePolicy)$","service_name":"google.compute","resource_name":"compute.routers.updateRoutePolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/serviceAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslCertificates/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/sslPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.subnetworks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}/expandIpCidrRange","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandIpCidrRange)$","service_name":"google.compute","resource_name":"compute.subnetworks.expandIpCidrRange"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/subnetworks/{subnetwork}/setPrivateIpGoogleAccess","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPrivateIpGoogleAccess)$","service_name":"google.compute","resource_name":"compute.subnetworks.setPrivateIpGoogleAccess"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetPools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/addHealthCheck","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.addHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/addInstance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.addInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/getHealth","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.targetPools.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/removeHealthCheck","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.removeHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/removeInstance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.removeInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/setBackup","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackup)$","service_name":"google.compute","resource_name":"compute.targetPools.setBackup"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetPools/{targetPool}/setSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetPools.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetTcpProxies/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/targetVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/regions/{region}/vpnTunnels/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setCloudArmorTier","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCloudArmorTier)$","service_name":"google.compute","resource_name":"compute.projects.setCloudArmorTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setCommonInstanceMetadata","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCommonInstanceMetadata)$","service_name":"google.compute","resource_name":"compute.projects.setCommonInstanceMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setDefaultNetworkTier","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultNetworkTier)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultNetworkTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setManagedProtectionTier","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setManagedProtectionTier)$","service_name":"google.compute","resource_name":"compute.projects.setManagedProtectionTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/setUsageExportBucket","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUsageExportBucket)$","service_name":"google.compute","resource_name":"compute.projects.setUsageExportBucket"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.autoscalers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.disks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.disks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.disks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.disks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.disks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/futureReservations/{futureReservation}/cancel","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.futureReservations.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeAdvanced","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeAdvanced)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resizeAdvanced"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}/cancel","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resumeInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resumeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resumeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setAutoHealingPolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setAutoHealingPolicies)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setAutoHealingPolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/startInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.startInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/stopInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.stopInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/suspendInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspendInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.suspendInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/addInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.addInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/removeInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.removeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.instanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/bulkInsert","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.instances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/addAccessConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.addAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/addResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/attachDisk","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachDisk)$","service_name":"google.compute","resource_name":"compute.instances.attachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/deleteAccessConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.deleteAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/detachDisk","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachDisk)$","service_name":"google.compute","resource_name":"compute.instances.detachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/patchPartnerMetadata","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPartnerMetadata)$","service_name":"google.compute","resource_name":"compute.instances.patchPartnerMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/performMaintenance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.instances.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/removeResourcePolicies","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/reset","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.compute","resource_name":"compute.instances.reset"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/resume","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.compute","resource_name":"compute.instances.resume"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/sendDiagnosticInterrupt","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendDiagnosticInterrupt)$","service_name":"google.compute","resource_name":"compute.instances.sendDiagnosticInterrupt"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setDiskAutoDelete","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDiskAutoDelete)$","service_name":"google.compute","resource_name":"compute.instances.setDiskAutoDelete"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instances.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMachineResources","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineResources)$","service_name":"google.compute","resource_name":"compute.instances.setMachineResources"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMachineType","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineType)$","service_name":"google.compute","resource_name":"compute.instances.setMachineType"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMetadata","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMetadata)$","service_name":"google.compute","resource_name":"compute.instances.setMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setMinCpuPlatform","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMinCpuPlatform)$","service_name":"google.compute","resource_name":"compute.instances.setMinCpuPlatform"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setName","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setName)$","service_name":"google.compute","resource_name":"compute.instances.setName"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setScheduling","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setScheduling)$","service_name":"google.compute","resource_name":"compute.instances.setScheduling"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setServiceAccount","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setServiceAccount)$","service_name":"google.compute","resource_name":"compute.instances.setServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/setTags","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTags)$","service_name":"google.compute","resource_name":"compute.instances.setTags"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/simulateMaintenanceEvent","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.instances.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/start","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.compute","resource_name":"compute.instances.start"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/startWithEncryptionKey","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startWithEncryptionKey)$","service_name":"google.compute","resource_name":"compute.instances.startWithEncryptionKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/stop","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.compute","resource_name":"compute.instances.stop"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/suspend","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.compute","resource_name":"compute.instances.suspend"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}/updateAccessConfig","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/setDeletionProtection","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDeletionProtection)$","service_name":"google.compute","resource_name":"compute.instances.setDeletionProtection"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/networkEndpointGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/addNodes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.addNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/deleteNodes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.deleteNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/listNodes","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.listNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/performMaintenance","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.nodeGroups.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/setNodeTemplate","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNodeTemplate)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setNodeTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/simulateMaintenanceEvent","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.nodeGroups.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/nodeGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/operations/{operation}/wait","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.zoneOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{reservation}/resize","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.reservations.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/reservations/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.reservations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools/{resource}/setIamPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/storagePools/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.storagePools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances/{resource}/testIamPermissions","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.targetInstances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/beta/projects/{project}/zones/{zone}/targetInstances/{targetInstance}/setSecurityPolicy","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetInstances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/move","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/locations/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/locations/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.firewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/disableXpnHost","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/disableXpnResource","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.disableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/enableXpnHost","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnHost)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnHost"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/enableXpnResource","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enableXpnResource)$","service_name":"google.compute","resource_name":"compute.projects.enableXpnResource"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses)$","service_name":"google.compute","resource_name":"compute.globalAddresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/addresses/{address}/move","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.globalAddresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/addresses/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalAddresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets)$","service_name":"google.compute","resource_name":"compute.backendBuckets.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}/addSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}/deleteSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendBuckets.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendBuckets.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendBuckets.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices)$","service_name":"google.compute","resource_name":"compute.backendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/addSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.addSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/deleteSignedUrlKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteSignedUrlKey)$","service_name":"google.compute","resource_name":"compute.backendServices.deleteSignedUrlKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.backendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/setEdgeSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setEdgeSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setEdgeSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.backendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.backendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/externalVpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/externalVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.externalVpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/firewalls","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls)$","service_name":"google.compute","resource_name":"compute.firewalls.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.globalForwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks)$","service_name":"google.compute","resource_name":"compute.healthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks)$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images)$","service_name":"google.compute","resource_name":"compute.images.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{image}/deprecate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deprecate)$","service_name":"google.compute","resource_name":"compute.images.deprecate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.images.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.images.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/images/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/images/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.images.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/instanceTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/instanceTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instanceTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/interconnects","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects)$","service_name":"google.compute","resource_name":"compute.interconnects.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/interconnects/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/interconnects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnects.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenseCodes/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenseCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenseCodes.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses)$","service_name":"google.compute","resource_name":"compute.licenses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenses/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.licenses.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/licenses/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/licenses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.licenses.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/machineImages","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages)$","service_name":"google.compute","resource_name":"compute.machineImages.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/machineImages/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.machineImages.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/machineImages/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/machineImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.machineImages.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.globalNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks)$","service_name":"google.compute","resource_name":"compute.networks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks/{network}/addPeering","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addPeering)$","service_name":"google.compute","resource_name":"compute.networks.addPeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks/{network}/removePeering","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removePeering)$","service_name":"google.compute","resource_name":"compute.networks.removePeering"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/networks/{network}/switchToCustomMode","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchToCustomMode)$","service_name":"google.compute","resource_name":"compute.networks.switchToCustomMode"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/operations/{operation}/wait","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.globalOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/announce","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/publicAdvertisedPrefixes/{publicAdvertisedPrefix}/withdraw","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicAdvertisedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicAdvertisedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.globalPublicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/routes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/routes)$","service_name":"google.compute","resource_name":"compute.routes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies)$","service_name":"google.compute","resource_name":"compute.securityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.securityPolicies.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.securityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots)$","service_name":"google.compute","resource_name":"compute.snapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.snapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.snapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/snapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.snapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslCertificates)$","service_name":"google.compute","resource_name":"compute.sslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/sslPolicies)$","service_name":"google.compute","resource_name":"compute.sslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetGrpcProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetGrpcProxies)$","service_name":"google.compute","resource_name":"compute.targetGrpcProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setCertificateMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setQuicOverride","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setQuicOverride)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setQuicOverride"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetHttpsProxies/{targetHttpsProxy}/setSslPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setBackendService","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setCertificateMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCertificateMap)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setCertificateMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setProxyHeader","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetSslProxies/{targetSslProxy}/setSslPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetSslProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslPolicy)$","service_name":"google.compute","resource_name":"compute.targetSslProxies.setSslPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setBackendService","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackendService)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setBackendService"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/targetTcpProxies/{targetTcpProxy}/setProxyHeader","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/targetTcpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setProxyHeader)$","service_name":"google.compute","resource_name":"compute.targetTcpProxies.setProxyHeader"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps)$","service_name":"google.compute","resource_name":"compute.urlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}/invalidateCache","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invalidateCache)$","service_name":"google.compute","resource_name":"compute.urlMaps.invalidateCache"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.urlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/listXpnHosts","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listXpnHosts)$","service_name":"google.compute","resource_name":"compute.projects.listXpnHosts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/moveDisk","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveDisk)$","service_name":"google.compute","resource_name":"compute.projects.moveDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/moveInstance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/moveInstance)$","service_name":"google.compute","resource_name":"compute.projects.moveInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses)$","service_name":"google.compute","resource_name":"compute.addresses.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{address}/move","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.compute","resource_name":"compute.addresses.move"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/addresses/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.addresses.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}/getHealth","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}/setSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionBackendServices.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/commitments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commitments)$","service_name":"google.compute","resource_name":"compute.regionCommitments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.regionDisks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/bulkInsert","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionDisks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.regionDisks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.regionDisks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionDisks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.regionDisks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionDisks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionDisks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionDisks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/addRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/cloneRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneRules)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.cloneRules"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/patchRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeAssociation","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeAssociation)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeAssociation"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{firewallPolicy}/removeRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/firewallPolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionNetworkFirewallPolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules)$","service_name":"google.compute","resource_name":"compute.forwardingRules.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{forwardingRule}/setTarget","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTarget)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setTarget"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/forwardingRules/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/forwardingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.forwardingRules.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/healthCheckServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthCheckServices)$","service_name":"google.compute","resource_name":"compute.regionHealthCheckServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks)$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.regionInstanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instanceTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceTemplates)$","service_name":"google.compute","resource_name":"compute.regionInstanceTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instances/bulkInsert","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.regionInstances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.regionInstantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/interconnectAttachments/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/interconnectAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.interconnectAttachments.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments)$","service_name":"google.compute","resource_name":"compute.networkAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.networkAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEdgeSecurityServices","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEdgeSecurityServices)$","service_name":"google.compute","resource_name":"compute.networkEdgeSecurityServices.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNetworkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/nodeTemplates/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeTemplates.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/notificationEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationEndpoints)$","service_name":"google.compute","resource_name":"compute.regionNotificationEndpoints.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/operations/{operation}/wait","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.regionOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/packetMirrorings/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/packetMirrorings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.packetMirrorings.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/announce","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/announce)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.announce"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/publicDelegatedPrefixes/{publicDelegatedPrefix}/withdraw","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publicDelegatedPrefixes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/withdraw)$","service_name":"google.compute","resource_name":"compute.publicDelegatedPrefixes.withdraw"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/resourcePolicies/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.resourcePolicies.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/routers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers)$","service_name":"google.compute","resource_name":"compute.routers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}/preview","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preview)$","service_name":"google.compute","resource_name":"compute.routers.preview"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/addRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.addRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/patchRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.patchRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/securityPolicies/{securityPolicy}/removeRule","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeRule)$","service_name":"google.compute","resource_name":"compute.regionSecurityPolicies.removeRule"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/serviceAttachments/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.serviceAttachments.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/sslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCertificates)$","service_name":"google.compute","resource_name":"compute.regionSslCertificates.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/sslPolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslPolicies)$","service_name":"google.compute","resource_name":"compute.regionSslPolicies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks)$","service_name":"google.compute","resource_name":"compute.subnetworks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.subnetworks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.subnetworks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}/expandIpCidrRange","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/expandIpCidrRange)$","service_name":"google.compute","resource_name":"compute.subnetworks.expandIpCidrRange"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/subnetworks/{subnetwork}/setPrivateIpGoogleAccess","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setPrivateIpGoogleAccess)$","service_name":"google.compute","resource_name":"compute.subnetworks.setPrivateIpGoogleAccess"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.regionTargetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools)$","service_name":"google.compute","resource_name":"compute.targetPools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/addHealthCheck","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.addHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/addInstance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.addInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/getHealth","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getHealth)$","service_name":"google.compute","resource_name":"compute.targetPools.getHealth"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/removeHealthCheck","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeHealthCheck)$","service_name":"google.compute","resource_name":"compute.targetPools.removeHealthCheck"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/removeInstance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstance)$","service_name":"google.compute","resource_name":"compute.targetPools.removeInstance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/setBackup","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setBackup)$","service_name":"google.compute","resource_name":"compute.targetPools.setBackup"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetPools/{targetPool}/setSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetPools.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetTcpProxies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetTcpProxies)$","service_name":"google.compute","resource_name":"compute.regionTargetTcpProxies.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/targetVpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetVpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.targetVpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}/validate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validate)$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.validate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways)$","service_name":"google.compute","resource_name":"compute.vpnGateways.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnGateways.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnGateways/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnGateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.vpnGateways.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/regions/{region}/vpnTunnels/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpnTunnels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.vpnTunnels.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/setCloudArmorTier","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCloudArmorTier)$","service_name":"google.compute","resource_name":"compute.projects.setCloudArmorTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/setCommonInstanceMetadata","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setCommonInstanceMetadata)$","service_name":"google.compute","resource_name":"compute.projects.setCommonInstanceMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/setDefaultNetworkTier","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefaultNetworkTier)$","service_name":"google.compute","resource_name":"compute.projects.setDefaultNetworkTier"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/setUsageExportBucket","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUsageExportBucket)$","service_name":"google.compute","resource_name":"compute.projects.setUsageExportBucket"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/targetHttpProxies/{targetHttpProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setSslCertificates","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSslCertificates)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setSslCertificates"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/targetHttpsProxies/{targetHttpsProxy}/setUrlMap","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetHttpsProxies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setUrlMap)$","service_name":"google.compute","resource_name":"compute.targetHttpsProxies.setUrlMap"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks)$","service_name":"google.compute","resource_name":"compute.disks.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/bulkInsert","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/bulkInsert)$","service_name":"google.compute","resource_name":"compute.disks.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/stopGroupAsyncReplication","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/stopGroupAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopGroupAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/addResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/createSnapshot","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createSnapshot)$","service_name":"google.compute","resource_name":"compute.disks.createSnapshot"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/removeResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.disks.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.disks.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/startAsyncReplication","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.startAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{disk}/stopAsyncReplication","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopAsyncReplication)$","service_name":"google.compute","resource_name":"compute.disks.stopAsyncReplication"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.disks.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.disks.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/disks/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.disks.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/futureReservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations)$","service_name":"google.compute","resource_name":"compute.futureReservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/futureReservations/{futureReservation}/cancel","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/futureReservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.futureReservations.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/abandonInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/abandonInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.abandonInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/applyUpdatesToInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/applyUpdatesToInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.applyUpdatesToInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/createInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.createInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deleteInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deleteInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/deletePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deletePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.deletePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listManagedInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listManagedInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listManagedInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/listPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.listPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/patchPerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchPerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.patchPerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/recreateInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recreateInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.recreateInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/resizeRequests/{resizeRequest}/cancel","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resizeRequests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagerResizeRequests.cancel"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setInstanceTemplate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setInstanceTemplate)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setInstanceTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/setTargetPools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTargetPools)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.setTargetPools"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}/updatePerInstanceConfigs","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatePerInstanceConfigs)$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.updatePerInstanceConfigs"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups)$","service_name":"google.compute","resource_name":"compute.instanceGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/addInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.addInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/listInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.listInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/removeInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeInstances)$","service_name":"google.compute","resource_name":"compute.instanceGroups.removeInstances"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instanceGroups/{instanceGroup}/setNamedPorts","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNamedPorts)$","service_name":"google.compute","resource_name":"compute.instanceGroups.setNamedPorts"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.compute","resource_name":"compute.instances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/bulkInsert","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/bulkInsert)$","service_name":"google.compute","resource_name":"compute.instances.bulkInsert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/addAccessConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.addAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/addResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.addResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/attachDisk","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachDisk)$","service_name":"google.compute","resource_name":"compute.instances.attachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/deleteAccessConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.deleteAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/detachDisk","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachDisk)$","service_name":"google.compute","resource_name":"compute.instances.detachDisk"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/performMaintenance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.instances.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/removeResourcePolicies","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeResourcePolicies)$","service_name":"google.compute","resource_name":"compute.instances.removeResourcePolicies"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/reset","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.compute","resource_name":"compute.instances.reset"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/resume","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.compute","resource_name":"compute.instances.resume"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/sendDiagnosticInterrupt","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sendDiagnosticInterrupt)$","service_name":"google.compute","resource_name":"compute.instances.sendDiagnosticInterrupt"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setDiskAutoDelete","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDiskAutoDelete)$","service_name":"google.compute","resource_name":"compute.instances.setDiskAutoDelete"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instances.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMachineResources","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineResources)$","service_name":"google.compute","resource_name":"compute.instances.setMachineResources"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMachineType","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMachineType)$","service_name":"google.compute","resource_name":"compute.instances.setMachineType"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMetadata","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMetadata)$","service_name":"google.compute","resource_name":"compute.instances.setMetadata"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setMinCpuPlatform","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setMinCpuPlatform)$","service_name":"google.compute","resource_name":"compute.instances.setMinCpuPlatform"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setName","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setName)$","service_name":"google.compute","resource_name":"compute.instances.setName"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setScheduling","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setScheduling)$","service_name":"google.compute","resource_name":"compute.instances.setScheduling"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setServiceAccount","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setServiceAccount)$","service_name":"google.compute","resource_name":"compute.instances.setServiceAccount"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/setTags","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setTags)$","service_name":"google.compute","resource_name":"compute.instances.setTags"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/simulateMaintenanceEvent","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.instances.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/start","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.compute","resource_name":"compute.instances.start"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/startWithEncryptionKey","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startWithEncryptionKey)$","service_name":"google.compute","resource_name":"compute.instances.startWithEncryptionKey"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/stop","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.compute","resource_name":"compute.instances.stop"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/suspend","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.compute","resource_name":"compute.instances.suspend"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}/updateAccessConfig","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateAccessConfig)$","service_name":"google.compute","resource_name":"compute.instances.updateAccessConfig"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/setDeletionProtection","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDeletionProtection)$","service_name":"google.compute","resource_name":"compute.instances.setDeletionProtection"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instances.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instances.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots/{resource}/setLabels","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLabels)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.setLabels"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/instantSnapshots/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instantSnapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.instantSnapshots.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/attachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.attachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/detachNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/detachNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.detachNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{networkEndpointGroup}/listNetworkEndpoints","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNetworkEndpoints)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.listNetworkEndpoints"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/networkEndpointGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkEndpointGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.networkEndpointGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.compute","resource_name":"compute.nodeGroups.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/addNodes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.addNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/deleteNodes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deleteNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.deleteNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/listNodes","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listNodes)$","service_name":"google.compute","resource_name":"compute.nodeGroups.listNodes"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/performMaintenance","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performMaintenance)$","service_name":"google.compute","resource_name":"compute.nodeGroups.performMaintenance"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/setNodeTemplate","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setNodeTemplate)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setNodeTemplate"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{nodeGroup}/simulateMaintenanceEvent","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulateMaintenanceEvent)$","service_name":"google.compute","resource_name":"compute.nodeGroups.simulateMaintenanceEvent"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.nodeGroups.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/nodeGroups/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.nodeGroups.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/operations/{operation}/wait","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/wait)$","service_name":"google.compute","resource_name":"compute.zoneOperations.wait"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.compute","resource_name":"compute.reservations.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{reservation}/resize","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.compute","resource_name":"compute.reservations.resize"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.reservations.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/reservations/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.reservations.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools)$","service_name":"google.compute","resource_name":"compute.storagePools.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools/{resource}/setIamPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.compute","resource_name":"compute.storagePools.setIamPolicy"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/storagePools/{resource}/testIamPermissions","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storagePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.compute","resource_name":"compute.storagePools.testIamPermissions"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances)$","service_name":"google.compute","resource_name":"compute.targetInstances.insert"},{"hostname":"compute.googleapis.com","http_method":"POST","path_template":"/compute/v1/projects/{project}/zones/{zone}/targetInstances/{targetInstance}/setSecurityPolicy","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSecurityPolicy)$","service_name":"google.compute","resource_name":"compute.targetInstances.setSecurityPolicy"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/alpha/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionInstanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/zones/{zone}/instanceGroupManagers/{instanceGroupManager}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceGroupManagers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instanceGroupManagers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/beta/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/backendBuckets/{backendBucket}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendBuckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendBuckets.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.backendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/firewalls/{firewall}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/firewalls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.firewalls.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.healthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/httpHealthChecks/{httpHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/httpsHealthChecks/{httpsHealthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/httpsHealthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.httpsHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/global/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.urlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.regionAutoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/backendServices/{backendService}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backendServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionBackendServices.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/healthChecks/{healthCheck}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/healthChecks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionHealthChecks.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/routers/{router}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.routers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/regions/{region}/urlMaps/{urlMap}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.regionUrlMaps.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/zones/{zone}/autoscalers","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalers)$","service_name":"google.compute","resource_name":"compute.autoscalers.update"},{"hostname":"compute.googleapis.com","http_method":"PUT","path_template":"/compute/v1/projects/{project}/zones/{zone}/instances/{instance}","path_regex":"^(?:/compute/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.compute","resource_name":"compute.instances.update"},{"hostname":"config.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.deployments.delete"},{"hostname":"config.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.operations.delete"},{"hostname":"config.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/previews/{previewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/previews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.previews.delete"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.config","resource_name":"config.projects.locations.list"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.get"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.list"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.deployments.get"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}/revisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.revisions.list"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.deployments.revisions.get"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}/revisions/{revisionsId}/resources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.revisions.resources.list"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}/revisions/{revisionsId}/resources/{resourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.deployments.revisions.resources.get"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:exportLock","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportLock)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.exportLock"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.getIamPolicy"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.config","resource_name":"config.projects.locations.operations.list"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.operations.get"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/previews","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/previews)$","service_name":"google.config","resource_name":"config.projects.locations.previews.list"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/previews/{previewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/previews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.previews.get"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/terraformVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/terraformVersions)$","service_name":"google.config","resource_name":"config.projects.locations.terraformVersions.list"},{"hostname":"config.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/terraformVersions/{terraformVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/terraformVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.terraformVersions.get"},{"hostname":"config.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.config","resource_name":"config.projects.locations.deployments.patch"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.create"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}/revisions/{revisionsId}:exportState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportState)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.revisions.exportState"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:deleteState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteState)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.deleteState"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:exportState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportState)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.exportState"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:importState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importState)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.importState"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:lock","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lock)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.lock"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.setIamPolicy"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.testIamPermissions"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/deployments/{deploymentsId}:unlock","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unlock)$","service_name":"google.config","resource_name":"config.projects.locations.deployments.unlock"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.config","resource_name":"config.projects.locations.operations.cancel"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/previews","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/previews)$","service_name":"google.config","resource_name":"config.projects.locations.previews.create"},{"hostname":"config.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/previews/{previewsId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/previews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.config","resource_name":"config.projects.locations.previews.export"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors/{customConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/managedZones/{managedZonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.managedZones.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/eventSubscriptions/{eventSubscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventSubscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.eventSubscriptions.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customConnectors/{customConnectorsId}/customConnectorVersions/{customConnectorVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.customConnectors.customConnectorVersions.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointAttachments/{endpointAttachmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.endpointAttachments.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.delete"},{"hostname":"connectors.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities/{entitiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.delete"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors/{customConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors/{customConnectorsId}/customConnectorVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectorVersions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.customConnectorVersions.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors/{customConnectorsId}/customConnectorVersions/{customConnectorVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.customConnectorVersions.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/managedZones","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/managedZones)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.managedZones.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/managedZones/{managedZonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.managedZones.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/settings)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.getSettings"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.getConnectionSchemaMetadata"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata:getAction","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata:getAction)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.connectionSchemaMetadata.getAction"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata:getEntityType","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata:getEntityType)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.connectionSchemaMetadata.getEntityType"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata:listActions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata:listActions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.connectionSchemaMetadata.listActions"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata:listEntityTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata:listEntityTypes)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.connectionSchemaMetadata.listEntityTypes"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/eventSubscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventSubscriptions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.eventSubscriptions.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/eventSubscriptions/{eventSubscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventSubscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.eventSubscriptions.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeActionSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeActionSchemas)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.runtimeActionSchemas.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeEntitySchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeEntitySchemas)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.runtimeEntitySchemas.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.getIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections:search)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.search"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointAttachments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.endpointAttachments.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointAttachments/{endpointAttachmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.endpointAttachments.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.versions.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.versions.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}/versions/{versionsId}/eventtypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventtypes)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.versions.eventtypes.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}/connectors/{connectorsId}/versions/{versionsId}/eventtypes/{eventtypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventtypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.connectors.versions.eventtypes.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.getIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/regionalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalSettings)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.getRegionalSettings"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimeConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeConfig)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.getRuntimeConfig"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/actions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.actions.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/actions/{actionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.actions.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.list"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities/{entitiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.get"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:checkReadiness","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkReadiness)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.checkReadiness"},{"hostname":"connectors.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:checkStatus","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkStatus)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.checkStatus"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors/{customConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.patch"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/managedZones/{managedZonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.managedZones.patch"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/settings)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.updateSettings"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.patch"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/eventSubscriptions/{eventSubscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventSubscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.eventSubscriptions.patch"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointAttachments/{endpointAttachmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.endpointAttachments.patch"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/regionalSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalSettings)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.updateRegionalSettings"},{"hostname":"connectors.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities/{entitiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.patch"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/customConnectors/{customConnectorsId}/customConnectorVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectorVersions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.customConnectors.customConnectorVersions.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/managedZones","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/managedZones)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.global.managedZones.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata:refresh","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata:refresh)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.connectionSchemaMetadata.refresh"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/eventSubscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventSubscriptions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.eventSubscriptions.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/eventSubscriptions/{eventSubscriptionsId}:retry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventSubscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retry)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.eventSubscriptions.retry"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:listenEvent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listenEvent)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.listenEvent"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:repairEventing","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repairEventing)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.repairEventing"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.setIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.testIamPermissions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customConnectors/{customConnectorsId}/customConnectorVersions/{customConnectorVersionsId}:deprecate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deprecate)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.customConnectors.customConnectorVersions.deprecate"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customConnectors:validateCustomConnectorSpec","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConnectors:validateCustomConnectorSpec)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.customConnectors.validateCustomConnectorSpec"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointAttachments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointAttachments)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.endpointAttachments.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.operations.cancel"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.setIamPolicy"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.providers.testIamPermissions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/actions/{actionsId}:execute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.actions.execute"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.create"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities:deleteEntitiesWithConditions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:deleteEntitiesWithConditions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.deleteEntitiesWithConditions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/entityTypes/{entityTypesId}/entities:updateEntitiesWithConditions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:updateEntitiesWithConditions)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.entityTypes.entities.updateEntitiesWithConditions"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:exchangeAuthCode","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAuthCode)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.exchangeAuthCode"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:executeSqlQuery","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeSqlQuery)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.executeSqlQuery"},{"hostname":"connectors.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:refreshAccessToken","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refreshAccessToken)$","service_name":"google.connectors","resource_name":"connectors.projects.locations.connections.refreshAccessToken"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters/{contactCentersId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.delete"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.delete"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.list"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.get"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.list"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters/{contactCentersId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.get"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.list"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.get"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}:queryContactCenterQuota","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryContactCenterQuota)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.queryContactCenterQuota"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters/{contactCentersId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.patch"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/contactCenters","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contactCenters)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.contactCenters.create"},{"hostname":"contactcenteraiplatform.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.contactcenteraiplatform","resource_name":"contactcenteraiplatform.projects.locations.operations.cancel"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses/{analysesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues/{issuesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers/{phraseMatchersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views/{viewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.delete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses/{analysesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:calculateStats","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:calculateStats)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.calculateStats"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/encryptionSpec","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionSpec)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.getEncryptionSpec"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues/{issuesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}:calculateIssueModelStats","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::calculateIssueModelStats)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.calculateIssueModelStats"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.operations.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.operations.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers/{phraseMatchersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.getSettings"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.list"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views/{viewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.get"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}/issues/{issuesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.issues.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers/{phraseMatchersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.updateSettings"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views/{viewsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.patch"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/analyses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyses)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.analyses.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:bulkAnalyze","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:bulkAnalyze)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.bulkAnalyze"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:bulkDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:bulkDelete)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.bulkDelete"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:ingest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:ingest)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.ingest"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversations:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations:upload)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.conversations.upload"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/encryptionSpec:initialize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionSpec:initialize)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.encryptionSpec.initialize"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightsdata:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightsdata:export)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.insightsdata.export"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}:deploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.deploy"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.export"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels/{issueModelsId}:undeploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.undeploy"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/issueModels:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issueModels:import)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.issueModels.import"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.operations.cancel"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseMatchers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseMatchers)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.phraseMatchers.create"},{"hostname":"contactcenterinsights.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/views","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.contactcenterinsights","resource_name":"contactcenterinsights.projects.locations.views.create"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.delete"},{"hostname":"container.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.delete"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.zones.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/operations/{operationId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/zones/{zone}/serverconfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverconfig)$","service_name":"google.container","resource_name":"container.projects.zones.getServerconfig"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/aggregated/usableSubnetworks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/usableSubnetworks)$","service_name":"google.container","resource_name":"container.projects.aggregated.usableSubnetworks.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/.well-known/openid-configuration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\.well-known/openid-configuration)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.well-known.getOpenid-configuration"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/jwks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jwks)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.getJwks"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:checkAutopilotCompatibility","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkAutopilotCompatibility)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.checkAutopilotCompatibility"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.locations.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverConfig)$","service_name":"google.container","resource_name":"container.projects.locations.getServerConfig"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.zones.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/operations/{operationId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/serverconfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverconfig)$","service_name":"google.container","resource_name":"container.projects.zones.getServerconfig"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/aggregated/usableSubnetworks","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aggregated/usableSubnetworks)$","service_name":"google.container","resource_name":"container.projects.aggregated.usableSubnetworks.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.container","resource_name":"container.projects.locations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/.well-known/openid-configuration","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\.well-known/openid-configuration)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.well-known.getOpenid-configuration"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/jwks","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jwks)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.getJwks"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:checkAutopilotCompatibility","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkAutopilotCompatibility)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.checkAutopilotCompatibility"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.container","resource_name":"container.projects.locations.operations.list"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.operations.get"},{"hostname":"container.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverConfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverConfig)$","service_name":"google.container","resource_name":"container.projects.locations.getServerConfig"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/addons","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addons)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.addons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/legacyAbac","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/legacyAbac)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.legacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.locations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/logging","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logging)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.logging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/master","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/master)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.master"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/monitoring","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoring)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.monitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/autoscaling","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscaling)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.autoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setManagement","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setManagement)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setSize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSize)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/update","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/update)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.update"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/resourceLabels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceLabels)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.resourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:completeIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMaintenancePolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMasterAuth","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setNetworkPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:startIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/zones/{zone}/operations/{operationId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.zones.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:completeUpgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeUpgrade)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.completeUpgrade"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setAutoscaling","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAutoscaling)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setAutoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setManagement","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setManagement)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setSize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSize)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:completeIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setAddons","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAddons)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setAddons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLegacyAbac","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLegacyAbac)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLegacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLocations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLocations)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLocations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLogging","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLogging)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLogging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMaintenancePolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMasterAuth","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMonitoring","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMonitoring)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMonitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setNetworkPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setResourceLabels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setResourceLabels)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setResourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:startIpRotation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:updateMaster","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateMaster)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.updateMaster"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.locations.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/addons","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addons)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.addons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/legacyAbac","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/legacyAbac)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.legacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.locations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/logging","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logging)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.logging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/master","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/master)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.master"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/monitoring","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoring)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.monitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/autoscaling","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscaling)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.autoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setManagement","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setManagement)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/setSize","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setSize)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}/update","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/update)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.update"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/nodePools/{nodePoolId}:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}/resourceLabels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceLabels)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.resourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:completeIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMaintenancePolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setMasterAuth","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:setNetworkPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}:startIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.zones.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/operations/{operationId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.zones.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.create"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:completeUpgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeUpgrade)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.completeUpgrade"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.rollback"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setAutoscaling","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAutoscaling)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setAutoscaling"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setManagement","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setManagement)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setManagement"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}:setSize","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSize)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.setSize"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:completeIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.completeIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setAddons","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAddons)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setAddons"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLegacyAbac","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLegacyAbac)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLegacyAbac"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLocations)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLocations"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setLogging","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLogging)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setLogging"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMaintenancePolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMaintenancePolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMaintenancePolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMasterAuth","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMasterAuth)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMasterAuth"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setMonitoring","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMonitoring)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setMonitoring"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setNetworkPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setNetworkPolicy)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setNetworkPolicy"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:setResourceLabels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setResourceLabels)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.setResourceLabels"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:startIpRotation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startIpRotation)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.startIpRotation"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}:updateMaster","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateMaster)$","service_name":"google.container","resource_name":"container.projects.locations.clusters.updateMaster"},{"hostname":"container.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.container","resource_name":"container.projects.locations.operations.cancel"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectId}/zones/{zone}/clusters/{clusterId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.zones.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.update"},{"hostname":"container.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/nodePools/{nodePoolsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.container","resource_name":"container.projects.locations.clusters.nodePools.update"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.delete"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/notes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.scanConfigs.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.scanConfigs.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/providers/{providersId}/notes","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.list"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.get"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getNotes"},{"hostname":"containeranalysis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/occurrences:vulnerabilitySummary","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:vulnerabilitySummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getVulnerabilitySummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.operations.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.scanConfigs.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.patch"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/notes:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/occurrences:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/resources/{resourcesId}:exportSBOM","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportSBOM)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.resources.exportSBOM"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notes:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences/{occurrencesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/occurrences:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/resources/{resourcesId}:exportSBOM","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportSBOM)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.resources.exportSBOM"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/occurrences/{occurrencesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.operations.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1alpha1/providers/{providersId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.providers.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/notes:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.notes.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/occurrences:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.occurrences.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/resources/{resourcesId}:exportSBOM","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportSBOM)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.resources.exportSBOM"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/resources/{resourcesId}:generatePackagesSummary","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generatePackagesSummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.locations.resources.generatePackagesSummary"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes/{notesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/notes:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.notes.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.create"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.getIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.setIamPolicy"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences/{occurrencesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.testIamPermissions"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/occurrences:batchCreate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/occurrences:batchCreate)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.occurrences.batchCreate"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/resources/{resourcesId}:exportSBOM","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportSBOM)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.resources.exportSBOM"},{"hostname":"containeranalysis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/resources/{resourcesId}:generatePackagesSummary","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generatePackagesSummary)$","service_name":"google.containeranalysis","resource_name":"containeranalysis.projects.resources.generatePackagesSummary"},{"hostname":"contentwarehouse.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas/{documentSchemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets/{ruleSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets/{synonymSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.list"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas/{documentSchemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.operations.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.list"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets/{ruleSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.list"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets/{synonymSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:getStatus","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getStatus)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.getStatus"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas/{documentSchemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/referenceId/{referenceIdId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/referenceId/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.referenceId.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets/{ruleSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets/{synonymSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.patch"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documentSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentSchemas)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documentSchemas.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/referenceId/{referenceIdId}:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/referenceId/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delete)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.referenceId.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/referenceId/{referenceIdId}:get","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/referenceId/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::get)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.referenceId.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/documentLinks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentLinks)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.documentLinks.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/documentLinks/{documentLinksId}:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delete)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.documentLinks.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/linkedSources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/linkedSources)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.linkedSources"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}/linkedTargets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/linkedTargets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.linkedTargets"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delete)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.delete"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:fetchAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.fetchAcl"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:get","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::get)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.get"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:lock","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lock)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.lock"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents/{documentsId}:setAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.setAcl"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/documents:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:search)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.documents.search"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/ruleSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ruleSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.ruleSets.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/synonymSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/synonymSets)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.synonymSets.create"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:initialize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initialize)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.initialize"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:runPipeline","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runPipeline)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.locations.runPipeline"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:fetchAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.fetchAcl"},{"hostname":"contentwarehouse.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:setAcl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAcl)$","service_name":"google.contentwarehouse","resource_name":"contentwarehouse.projects.setAcl"},{"hostname":"css.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/cssProductInputs/{cssProductInputsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cssProductInputs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.css","resource_name":"css.accounts.cssProductInputs.delete"},{"hostname":"css.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/labels/{labelsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.css","resource_name":"css.accounts.labels.delete"},{"hostname":"css.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.css","resource_name":"css.accounts.get"},{"hostname":"css.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/cssProducts","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cssProducts)$","service_name":"google.css","resource_name":"css.accounts.cssProducts.list"},{"hostname":"css.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/cssProducts/{cssProductsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cssProducts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.css","resource_name":"css.accounts.cssProducts.get"},{"hostname":"css.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/labels","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.css","resource_name":"css.accounts.labels.list"},{"hostname":"css.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}:listChildAccounts","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listChildAccounts)$","service_name":"google.css","resource_name":"css.accounts.listChildAccounts"},{"hostname":"css.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/labels/{labelsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.css","resource_name":"css.accounts.labels.patch"},{"hostname":"css.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/cssProductInputs:insert","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cssProductInputs:insert)$","service_name":"google.css","resource_name":"css.accounts.cssProductInputs.insert"},{"hostname":"css.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/labels","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.css","resource_name":"css.accounts.labels.create"},{"hostname":"css.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}:updateLabels","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateLabels)$","service_name":"google.css","resource_name":"css.accounts.updateLabels"},{"hostname":"customsearch.googleapis.com","http_method":"GET","path_template":"/customsearch/v1","path_regex":"^(?:/customsearch/v1)$","service_name":"google.customsearch","resource_name":"search.cse.list"},{"hostname":"customsearch.googleapis.com","http_method":"GET","path_template":"/customsearch/v1/siterestrict","path_regex":"^(?:/customsearch/v1/siterestrict)$","service_name":"google.customsearch","resource_name":"search.cse.siterestrict.list"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.delete"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/entries:lookup","path_regex":"^(?:/v1/entries:lookup)$","service_name":"google.datacatalog","resource_name":"datacatalog.entries.lookup"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:export)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.export"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/entries:lookup","path_regex":"^(?:/v1beta1/entries:lookup)$","service_name":"google.datacatalog","resource_name":"datacatalog.entries.lookup"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.list"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.get"},{"hostname":"datacatalog.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:export)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.export"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags/{tagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.patch"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/catalog:search","path_regex":"^(?:/v1/catalog:search)$","service_name":"google.datacatalog","resource_name":"datacatalog.catalog.search"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags:reconcile","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags:reconcile)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.reconcile"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:modifyEntryContacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyEntryContacts)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.modifyEntryContacts"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:modifyEntryOverview","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyEntryOverview)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.modifyEntryOverview"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:star","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::star)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.star"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:unstar","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unstar)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.unstar"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries:import)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.import"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.operations.cancel"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}/enumValues/{enumValuesId}:rename","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enumValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.enumValues.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}:rename","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:replace","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::replace)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.replace"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/taxonomies:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:import)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.import"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/catalog:search","path_regex":"^(?:/v1beta1/catalog:search)$","service_name":"google.datacatalog","resource_name":"datacatalog.catalog.search"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.entries.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/tags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.tags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.entryGroups.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}/enumValues/{enumValuesId}:rename","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enumValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.enumValues.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}/fields/{fieldsId}:rename","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rename)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.fields.rename"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tagTemplates/{tagTemplatesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tagTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.tagTemplates.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.create"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}/policyTags/{policyTagsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policyTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.policyTags.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.getIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.setIamPolicy"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies/{taxonomiesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.testIamPermissions"},{"hostname":"datacatalog.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/taxonomies:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/taxonomies:import)$","service_name":"google.datacatalog","resource_name":"datacatalog.projects.locations.taxonomies.import"},{"hostname":"dataflow.googleapis.com","http_method":"DELETE","path_template":"/v1b3/projects/{projectId}/locations/{location}/snapshots/{snapshotId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.snapshots.delete"},{"hostname":"dataflow.googleapis.com","http_method":"DELETE","path_template":"/v1b3/projects/{projectId}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.deleteSnapshots"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/messages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.messages.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/metrics","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.getMetrics"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/jobs:aggregated","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:aggregated)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.aggregated"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/executionDetails","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionDetails)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.getExecutionDetails"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/messages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.messages.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/metrics","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.getMetrics"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.snapshots.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/stages/{stageId}/executionDetails","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionDetails)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.stages.getExecutionDetails"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.snapshots.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/snapshots/{snapshotId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.snapshots.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/locations/{location}/templates:get","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:get)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.templates.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/snapshots","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.dataflow","resource_name":"dataflow.projects.snapshots.list"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/snapshots/{snapshotId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.snapshots.get"},{"hostname":"dataflow.googleapis.com","http_method":"GET","path_template":"/v1b3/projects/{projectId}/templates:get","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:get)$","service_name":"google.dataflow","resource_name":"dataflow.projects.templates.get"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/WorkerMessages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/WorkerMessages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.workerMessages"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/debug/getConfig","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/getConfig)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.debug.getConfig"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/debug/sendCapture","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/sendCapture)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.debug.sendCapture"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/workItems:lease","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:lease)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.workItems.lease"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}/workItems:reportStatus","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:reportStatus)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.workItems.reportStatus"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}:snapshot","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::snapshot)$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.snapshot"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/WorkerMessages","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/WorkerMessages)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.workerMessages"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/flexTemplates:launch","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flexTemplates:launch)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.flexTemplates.launch"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/debug/getConfig","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/getConfig)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.debug.getConfig"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/debug/sendCapture","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debug/sendCapture)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.debug.sendCapture"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/workItems:lease","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:lease)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.workItems.lease"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}/workItems:reportStatus","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workItems:reportStatus)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.workItems.reportStatus"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}:snapshot","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::snapshot)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.snapshot"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/templates","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.templates.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/locations/{location}/templates:launch","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:launch)$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.templates.launch"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/templates","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.dataflow","resource_name":"dataflow.projects.templates.create"},{"hostname":"dataflow.googleapis.com","http_method":"POST","path_template":"/v1b3/projects/{projectId}/templates:launch","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates:launch)$","service_name":"google.dataflow","resource_name":"dataflow.projects.templates.launch"},{"hostname":"dataflow.googleapis.com","http_method":"PUT","path_template":"/v1b3/projects/{projectId}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.jobs.update"},{"hostname":"dataflow.googleapis.com","http_method":"PUT","path_template":"/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}","path_regex":"^(?:/v1b3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataflow","resource_name":"dataflow.projects.locations.jobs.update"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs/{releaseConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs/{workflowConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.delete"},{"hostname":"dataform.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.delete"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.collections.getIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/commentThreads/{commentThreadsId}/comments/{commentsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commentThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.commentThreads.comments.getIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/commentThreads/{commentThreadsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commentThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.commentThreads.getIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults/{compilationResultsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults/{compilationResultsId}:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::query)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.query"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs/{releaseConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs/{workflowConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::query)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.query"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.list"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.get"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:fetchFileDiff","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchFileDiff)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.fetchFileDiff"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:fetchFileGitStatuses","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchFileGitStatuses)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.fetchFileGitStatuses"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:fetchGitAheadBehind","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchGitAheadBehind)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.fetchGitAheadBehind"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.getIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:queryDirectoryContents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryDirectoryContents)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.queryDirectoryContents"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:readFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.readFile"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:searchFiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchFiles)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.searchFiles"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:computeAccessTokenStatus","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeAccessTokenStatus)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.computeAccessTokenStatus"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:fetchHistory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchHistory)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.fetchHistory"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:fetchRemoteBranches","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchRemoteBranches)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.fetchRemoteBranches"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.getIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:queryDirectoryContents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryDirectoryContents)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.queryDirectoryContents"},{"hostname":"dataform.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:readFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::readFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.readFile"},{"hostname":"dataform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.patch"},{"hostname":"dataform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs/{releaseConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.patch"},{"hostname":"dataform.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs/{workflowConfigsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.patch"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.collections.setIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.collections.testIamPermissions"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/commentThreads/{commentThreadsId}/comments/{commentsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commentThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.commentThreads.comments.setIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/commentThreads/{commentThreadsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/commentThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.commentThreads.setIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/compilationResults","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compilationResults)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.compilationResults.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/releaseConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.releaseConfigs.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowConfigs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowConfigs)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowConfigs.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workflowInvocations/{workflowInvocationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowInvocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workflowInvocations.cancel"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.create"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:commit","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.commit"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:installNpmPackages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::installNpmPackages)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.installNpmPackages"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:makeDirectory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::makeDirectory)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.makeDirectory"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:moveDirectory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveDirectory)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.moveDirectory"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:moveFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.moveFile"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:pull","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pull)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.pull"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:push","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::push)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.push"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:removeDirectory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeDirectory)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.removeDirectory"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:removeFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.removeFile"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:reset","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.reset"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.setIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.testIamPermissions"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}/workspaces/{workspacesId}:writeFile","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::writeFile)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.workspaces.writeFile"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:commit","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.commit"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.setIamPolicy"},{"hostname":"dataform.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/repositories/{repositoriesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repositories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataform","resource_name":"dataform.projects.locations.repositories.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings/{dnsPeeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings/{dnsPeeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.delete"},{"hostname":"datafusion.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.delete"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.getIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.versions.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces/{namespacesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.getIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.getIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.list"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.get"},{"hostname":"datafusion.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.versions.list"},{"hostname":"datafusion.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.patch"},{"hostname":"datafusion.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.patch"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.restart"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.setIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.cancel"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/dnsPeerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsPeerings)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.dnsPeerings.create"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces/{namespacesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.setIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/namespaces/{namespacesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.namespaces.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restart","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.restart"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.setIamPolicy"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.testIamPermissions"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.instances.upgrade"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.operations.cancel"},{"hostname":"datafusion.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/{locationsId1}:removeIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeIamPolicy)$","service_name":"google.datafusion","resource_name":"datafusion.projects.locations.removeIamPolicy"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets/{annotationSpecSetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages/{feedbackMessagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/instructions/{instructionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.delete"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets/{annotationSpecSetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/dataItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.dataItems.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/dataItems/{dataItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.dataItems.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/examples","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.examples.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/examples/{examplesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.examples.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages/{feedbackMessagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/dataItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.dataItems.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/dataItems/{dataItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.dataItems.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.evaluations.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/evaluations:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations:search)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluations.search"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/instructions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/instructions/{instructionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.list"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.get"},{"hostname":"datalabeling.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.operations.cancel"},{"hostname":"datalabeling.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.patch"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/annotationSpecSets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationSpecSets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.annotationSpecSets.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/annotatedDatasets/{annotatedDatasetsId}/feedbackThreads/{feedbackThreadsId}/feedbackMessages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotatedDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackThreads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackMessages)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.annotatedDatasets.feedbackThreads.feedbackMessages.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/evaluations/{evaluationsId}/exampleComparisons:search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exampleComparisons:search)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.evaluations.exampleComparisons.search"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/image:label","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/image:label)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.image.label"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/text:label","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/text:label)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.text.label"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}/video:label","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/video:label)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.video.label"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}:exportData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportData)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.exportData"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/datasets/{datasetsId}:importData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importData)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.datasets.importData"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.create"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}:pause","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.pause"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/evaluationJobs/{evaluationJobsId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.evaluationJobs.resume"},{"hostname":"datalabeling.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/instructions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instructions)$","service_name":"google.datalabeling","resource_name":"datalabeling.projects.instructions.create"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.delete"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.delete"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.delete"},{"hostname":"datalineage.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents/{lineageEventsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.delete"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.get"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.get"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.get"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.list"},{"hostname":"datalineage.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents/{lineageEventsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.get"},{"hostname":"datalineage.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.patch"},{"hostname":"datalineage.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.patch"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.operations.cancel"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.create"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.create"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processes/{processesId}/runs/{runsId}/lineageEvents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineageEvents)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.processes.runs.lineageEvents.create"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:batchSearchLinkProcesses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchSearchLinkProcesses)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.batchSearchLinkProcesses"},{"hostname":"datalineage.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:searchLinks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchLinks)$","service_name":"google.datalineage","resource_name":"datalineage.projects.locations.searchLinks"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}/mappingRules/{mappingRulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mappingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.mappingRules.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.delete"},{"hostname":"datamigration.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.delete"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}/mappingRules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mappingRules)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.mappingRules.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}/mappingRules/{mappingRulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mappingRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.mappingRules.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:describeConversionWorkspaceRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::describeConversionWorkspaceRevisions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.describeConversionWorkspaceRevisions"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:describeDatabaseEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::describeDatabaseEntities)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.describeDatabaseEntities"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:searchBackgroundJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchBackgroundJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.searchBackgroundJobs"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:fetchStaticIps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchStaticIps)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.fetchStaticIps"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.get"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.getIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.list"},{"hostname":"datamigration.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.get"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.patch"},{"hostname":"datamigration.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.patch"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}/mappingRules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mappingRules)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.mappingRules.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}/mappingRules:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mappingRules:import)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.mappingRules.import"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:apply","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::apply)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.apply"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.commit"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:convert","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::convert)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.convert"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.rollback"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:seed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::seed)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.seed"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/conversionWorkspaces/{conversionWorkspacesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.conversionWorkspaces.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:demoteDestination","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::demoteDestination)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.demoteDestination"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:generateSshScript","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateSshScript)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.generateSshScript"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:generateTcpProxyScript","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateTcpProxyScript)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.generateTcpProxyScript"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:promote","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promote)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.promote"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.restart"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.resume"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.start"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.stop"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:verify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.verify"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.cancel"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.privateConnections.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.connectionProfiles.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.create"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:generateSshScript","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateSshScript)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.generateSshScript"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:promote","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promote)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.promote"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:restart","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.restart"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:resume","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.resume"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.setIamPolicy"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:start","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.start"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:stop","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.stop"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.testIamPermissions"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/migrationJobs/{migrationJobsId}:verify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.migrationJobs.verify"},{"hostname":"datamigration.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datamigration","resource_name":"datamigration.projects.locations.operations.cancel"},{"hostname":"datapipelines.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.delete"},{"hostname":"datapipelines.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.list"},{"hostname":"datapipelines.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.get"},{"hostname":"datapipelines.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.jobs.list"},{"hostname":"datapipelines.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.patch"},{"hostname":"datapipelines.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.create"},{"hostname":"datapipelines.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.run"},{"hostname":"datapipelines.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/pipelines/{pipelinesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.datapipelines","resource_name":"datapipelines.projects.locations.pipelines.stop"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes/{aspectTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.entries.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes/{entryTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions/{partitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.delete"},{"hostname":"dataplex.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.delete"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/encryptionConfigs/{encryptionConfigsId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.organizations.locations.encryptionConfigs.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes/{aspectTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes/{aspectTypesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.jobs.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.jobs.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.entries.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.entries.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes/{entryTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes/{entryTypesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.glossaries.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/governanceRules/{governanceRulesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/governanceRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.governanceRules.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/actions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.actions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.sessions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.jobs.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.jobs.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/actions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.actions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}/actions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.actions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions/{partitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.getIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataJobs)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.metadataJobs.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataJobs/{metadataJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.metadataJobs.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.list"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.get"},{"hostname":"dataplex.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:lookupEntry","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupEntry)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lookupEntry"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes/{aspectTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries/{entriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.entries.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes/{entryTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.patch"},{"hostname":"dataplex.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.patch"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/encryptionConfigs/{encryptionConfigsId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.organizations.locations.encryptionConfigs.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/encryptionConfigs/{encryptionConfigsId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.organizations.locations.encryptionConfigs.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes/{aspectTypesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/aspectTypes/{aspectTypesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aspectTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.aspectTypes.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataAttributeBindings/{dataAttributeBindingsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataAttributeBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataAttributeBindings.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}/jobs/{jobsId}:generateDataQualityRules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDataQualityRules)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.jobs.generateDataQualityRules"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:generateDataQualityRules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateDataQualityRules)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.generateDataQualityRules"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.run"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataScans/{dataScansId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataScans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataScans.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}/attributes/{attributesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.attributes.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataTaxonomies/{dataTaxonomiesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataTaxonomies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.dataTaxonomies.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}/entries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.entries.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryGroups/{entryGroupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryGroups.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes/{entryTypesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/entryTypes/{entryTypesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entryTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.entryTypes.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.glossaries.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.glossaries.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/governanceRules/{governanceRulesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/governanceRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.governanceRules.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/governanceRules/{governanceRulesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/governanceRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.governanceRules.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/content/{contentId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.content.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/contentitems/{contentitemsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentitems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.contentitems.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/environments/{environmentsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.environments.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}/jobs/{jobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.jobs.cancel"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.run"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/tasks/{tasksId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.tasks.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/assets/{assetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.assets.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}/partitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.partitions.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.setIamPolicy"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.testIamPermissions"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataJobs)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.metadataJobs.create"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/metadataJobs/{metadataJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.metadataJobs.cancel"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.operations.cancel"},{"hostname":"dataplex.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:searchEntries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchEntries)$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.searchEntries"},{"hostname":"dataplex.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lakes/{lakesId}/zones/{zonesId}/entities/{entitiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lakes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataplex","resource_name":"dataplex.projects.locations.lakes.zones.entities.update"},{"hostname":"dataportability.googleapis.com","http_method":"GET","path_template":"/v1/archiveJobs/{archiveJobsId}/portabilityArchiveState","path_regex":"^(?:/v1/archiveJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/portabilityArchiveState)$","service_name":"google.dataportability","resource_name":"dataportability.archiveJobs.getPortabilityArchiveState"},{"hostname":"dataportability.googleapis.com","http_method":"GET","path_template":"/v1beta/archiveJobs/{archiveJobsId}/portabilityArchiveState","path_regex":"^(?:/v1beta/archiveJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/portabilityArchiveState)$","service_name":"google.dataportability","resource_name":"dataportability.archiveJobs.getPortabilityArchiveState"},{"hostname":"dataportability.googleapis.com","http_method":"POST","path_template":"/v1/archiveJobs/{archiveJobsId}:retry","path_regex":"^(?:/v1/archiveJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retry)$","service_name":"google.dataportability","resource_name":"dataportability.archiveJobs.retry"},{"hostname":"dataportability.googleapis.com","http_method":"POST","path_template":"/v1/authorization:reset","path_regex":"^(?:/v1/authorization:reset)$","service_name":"google.dataportability","resource_name":"dataportability.authorization.reset"},{"hostname":"dataportability.googleapis.com","http_method":"POST","path_template":"/v1/portabilityArchive:initiate","path_regex":"^(?:/v1/portabilityArchive:initiate)$","service_name":"google.dataportability","resource_name":"dataportability.portabilityArchive.initiate"},{"hostname":"dataportability.googleapis.com","http_method":"POST","path_template":"/v1beta/archiveJobs/{archiveJobsId}:retry","path_regex":"^(?:/v1beta/archiveJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retry)$","service_name":"google.dataportability","resource_name":"dataportability.archiveJobs.retry"},{"hostname":"dataportability.googleapis.com","http_method":"POST","path_template":"/v1beta/authorization:reset","path_regex":"^(?:/v1beta/authorization:reset)$","service_name":"google.dataportability","resource_name":"dataportability.authorization.reset"},{"hostname":"dataportability.googleapis.com","http_method":"POST","path_template":"/v1beta/portabilityArchive:initiate","path_regex":"^(?:/v1beta/portabilityArchive:initiate)$","service_name":"google.dataportability","resource_name":"dataportability.portabilityArchive.initiate"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches/{batchesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessionTemplates/{sessionTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessionTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessionTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessions.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.delete"},{"hostname":"dataproc.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.delete"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches/{batchesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessionTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessionTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessionTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessionTemplates/{sessionTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessionTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessionTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessions.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessions.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}/nodeGroups/{nodeGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.nodeGroups.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.list"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.get"},{"hostname":"dataproc.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.patch"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.patch"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessionTemplates/{sessionTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessionTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessionTemplates.patch"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.patch"},{"hostname":"dataproc.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.patch"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:diagnose","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.diagnose"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:repair","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.repair"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.start"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/clusters/{clusterName}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.stop"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/jobs/{jobId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/jobs:submit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submit)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submit"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/regions/{region}/jobs:submitAsOperation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submitAsOperation)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submitAsOperation"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/batches/{batchesId}:analyze","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/batches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyze)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.batches.analyze"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.operations.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessionTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessionTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessionTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessions.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sessions/{sessionsId}:terminate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::terminate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.sessions.terminate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}/nodeGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.nodeGroups.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}/nodeGroups/{nodeGroupsId}:repair","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.nodeGroups.repair"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}/nodeGroups/{nodeGroupsId}:resize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resize)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.nodeGroups.resize"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:injectCredentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::injectCredentials)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.injectCredentials"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.getIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}:diagnose","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.diagnose"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}:start","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.start"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/clusters/{clusterName}:stop","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.stop"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs/{jobId}:cancel","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs:submit","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submit)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submit"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectId}/regions/{region}/jobs:submitAsOperation","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:submitAsOperation)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.submitAsOperation"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:injectCredentials","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::injectCredentials)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.injectCredentials"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/clusters/{clustersId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.clusters.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.jobs.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.cancel"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/operations/{operationsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.operations.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.create"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:instantiate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::instantiate)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiate"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.setIamPolicy"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.testIamPermissions"},{"hostname":"dataproc.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates:instantiateInline","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates:instantiateInline)$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.instantiateInline"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.locations.workflowTemplates.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/autoscalingPolicies/{autoscalingPoliciesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/autoscalingPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.autoscalingPolicies.update"},{"hostname":"dataproc.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/regions/{regionsId}/workflowTemplates/{workflowTemplatesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflowTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dataproc","resource_name":"dataproc.projects.regions.workflowTemplates.update"},{"hostname":"datastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectId}/indexes/{indexId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.delete"},{"hostname":"datastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.operations.delete"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.list"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/indexes/{indexId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.get"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datastore","resource_name":"datastore.projects.operations.list"},{"hostname":"datastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastore","resource_name":"datastore.projects.operations.get"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.datastore","resource_name":"datastore.projects.indexes.create"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:allocateIds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::allocateIds)$","service_name":"google.datastore","resource_name":"datastore.projects.allocateIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:beginTransaction","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::beginTransaction)$","service_name":"google.datastore","resource_name":"datastore.projects.beginTransaction"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.datastore","resource_name":"datastore.projects.commit"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.datastore","resource_name":"datastore.projects.export"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.datastore","resource_name":"datastore.projects.import"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookup)$","service_name":"google.datastore","resource_name":"datastore.projects.lookup"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:reserveIds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reserveIds)$","service_name":"google.datastore","resource_name":"datastore.projects.reserveIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.datastore","resource_name":"datastore.projects.rollback"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:runAggregationQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runAggregationQuery"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}:runQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runQuery"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datastore","resource_name":"datastore.projects.operations.cancel"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.datastore","resource_name":"datastore.projects.export"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.datastore","resource_name":"datastore.projects.import"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:allocateIds","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::allocateIds)$","service_name":"google.datastore","resource_name":"datastore.projects.allocateIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:beginTransaction","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::beginTransaction)$","service_name":"google.datastore","resource_name":"datastore.projects.beginTransaction"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:commit","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.datastore","resource_name":"datastore.projects.commit"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:lookup","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookup)$","service_name":"google.datastore","resource_name":"datastore.projects.lookup"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:reserveIds","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reserveIds)$","service_name":"google.datastore","resource_name":"datastore.projects.reserveIds"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:rollback","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.datastore","resource_name":"datastore.projects.rollback"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:runAggregationQuery","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runAggregationQuery"},{"hostname":"datastore.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectId}:runQuery","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.datastore","resource_name":"datastore.projects.runQuery"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.delete"},{"hostname":"datastream.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.delete"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:fetchStaticIps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchStaticIps)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.fetchStaticIps"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes/{routesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.list"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.get"},{"hostname":"datastream.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}:fetchStaticIps","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchStaticIps)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.fetchStaticIps"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.patch"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.patch"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles/{connectionProfilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.patch"},{"hostname":"datastream.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.patch"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectionProfiles:discover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles:discover)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.discover"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.cancel"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:startBackfillJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.startBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:stopBackfillJob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.stopBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects:lookup)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.lookup"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.run"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/connectionProfiles:discover","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionProfiles:discover)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.connectionProfiles.discover"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.operations.cancel"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/routes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.privateConnections.routes.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.create"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:startBackfillJob","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.startBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}/objects/{objectsId}:stopBackfillJob","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/objects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stopBackfillJob)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.objects.stopBackfillJob"},{"hostname":"datastream.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/streams/{streamsId}:fetchErrors","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/streams/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchErrors)$","service_name":"google.datastream","resource_name":"datastream.projects.locations.streams.fetchErrors"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"DELETE","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.delete"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/manifests","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/manifests/{manifest}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/resources","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/resources/{resource}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{resource}/getIamPolicy","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.getIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/operations","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/operations/{operation}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}/types","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.listTypes"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}/types/{type}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.getType"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/types","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/alpha/projects/{project}/global/types/{type}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/manifests","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/manifests/{manifest}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/resources","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/resources/{resource}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{resource}/getIamPolicy","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.getIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/operations","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/operations/{operation}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2/projects/{project}/global/types","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/manifests","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/manifests/{manifest}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manifests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.manifests.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/resources","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/resources/{resource}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.resources.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{resource}/getIamPolicy","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.getIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/operations","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/operations/{operation}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.operations.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.get"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}/types","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.listTypes"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}/types/{type}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/types/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.getType"},{"hostname":"deploymentmanager.googleapis.com","http_method":"GET","path_template":"/deploymentmanager/v2beta/projects/{project}/global/types","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/types)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.types.list"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PATCH","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.patch"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/cancelPreview","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelPreview)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.cancelPreview"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}/stop","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.stop"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{resource}/setIamPolicy","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.setIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{resource}/testIamPermissions","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.testIamPermissions"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/cancelPreview","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelPreview)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.cancelPreview"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}/stop","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.stop"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{resource}/setIamPolicy","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.setIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{resource}/testIamPermissions","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.testIamPermissions"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/cancelPreview","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelPreview)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.cancelPreview"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}/stop","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.stop"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{resource}/setIamPolicy","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setIamPolicy)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.setIamPolicy"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{resource}/testIamPermissions","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testIamPermissions)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.testIamPermissions"},{"hostname":"deploymentmanager.googleapis.com","http_method":"POST","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders)$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.insert"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/alpha/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/alpha/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/alpha/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2beta/projects/{project}/global/compositeTypes/{compositeType}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/compositeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.compositeTypes.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2beta/projects/{project}/global/deployments/{deployment}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.deployments.update"},{"hostname":"deploymentmanager.googleapis.com","http_method":"PUT","path_template":"/deploymentmanager/v2beta/projects/{project}/global/typeProviders/{typeProvider}","path_regex":"^(?:/deploymentmanager/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/typeProviders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.deploymentmanager","resource_name":"deploymentmanager.typeProviders.update"},{"hostname":"developerconnect.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.delete"},{"hostname":"developerconnect.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/gitRepositoryLinks/{gitRepositoryLinksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitRepositoryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.gitRepositoryLinks.delete"},{"hostname":"developerconnect.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.operations.delete"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.list"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.get"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.list"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.get"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/gitRepositoryLinks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitRepositoryLinks)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.gitRepositoryLinks.list"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/gitRepositoryLinks/{gitRepositoryLinksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitRepositoryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.gitRepositoryLinks.get"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/gitRepositoryLinks/{gitRepositoryLinksId}:fetchGitRefs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitRepositoryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchGitRefs)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.gitRepositoryLinks.fetchGitRefs"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:fetchGitHubInstallations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchGitHubInstallations)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.fetchGitHubInstallations"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}:fetchLinkableGitRepositories","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchLinkableGitRepositories)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.fetchLinkableGitRepositories"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.operations.list"},{"hostname":"developerconnect.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.operations.get"},{"hostname":"developerconnect.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.patch"},{"hostname":"developerconnect.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.create"},{"hostname":"developerconnect.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/gitRepositoryLinks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitRepositoryLinks)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.gitRepositoryLinks.create"},{"hostname":"developerconnect.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/gitRepositoryLinks/{gitRepositoryLinksId}:fetchReadToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitRepositoryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchReadToken)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.gitRepositoryLinks.fetchReadToken"},{"hostname":"developerconnect.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/gitRepositoryLinks/{gitRepositoryLinksId}:fetchReadWriteToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gitRepositoryLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchReadWriteToken)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.connections.gitRepositoryLinks.fetchReadWriteToken"},{"hostname":"developerconnect.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.developerconnect","resource_name":"developerconnect.projects.locations.operations.cancel"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserGroups/{advertiserGroupsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/contentCategories/{contentCategoriesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}/creativeFieldValues/{creativeFieldValuesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/dynamicTargetingKeys/{dynamicTargetingKeysId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/eventTags/{eventTagsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivities/{floodlightActivitiesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementStrategies/{placementStrategiesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRoles/{userRolesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.3/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.4/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v4/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles","path_regex":"^(?:/dfareporting/v4/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/accountUserProfiles/{accountUserProfilesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountActiveAdSummaries/{accountActiveAdSummariesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountPermissionGroups/{accountPermissionGroupsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountPermissions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountPermissions/{accountPermissionsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accounts/{accountsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/ads/{adsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserGroups/{advertiserGroupsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserLandingPages/{advertiserLandingPagesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertisers/{advertisersId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertisers/{advertisersId}/invoices","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserInvoices.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/billingProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingProfiles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/billingProfiles/{billingProfilesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.billingProfiles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/billingProfiles/{billingProfilesId}/billingAssignments","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingAssignments)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingAssignments.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/billingProfiles/{billingProfilesId}/billingRates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingRates)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingRates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/browsers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/campaigns/{campaignsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/campaigns/{campaignsId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/changeLogs","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/changeLogs/{changeLogsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/cities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/connectionTypes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/connectionTypes/{connectionTypesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/contentCategories/{contentCategoriesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/countries","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/countries/{countriesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}/creativeFieldValues/{creativeFieldValuesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeGroups/{creativeGroupsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creatives/{creativesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/directorySites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/directorySites/{directorySitesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/eventTags/{eventTagsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivities/{floodlightActivitiesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivityGroups/{floodlightActivityGroupsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightConfigurations/{floodlightConfigurationsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/languages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/metros","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/mobileApps","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/mobileApps/{mobileAppsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/mobileCarriers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/mobileCarriers/{mobileCarriersId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/operatingSystemVersions/{operatingSystemVersionsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/operatingSystems","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/operatingSystems/{operatingSystemsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementGroups/{placementGroupsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementStrategies/{placementStrategiesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placements/{placementsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/platformTypes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/platformTypes/{platformTypesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/postalCodes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/postalCodes/{postalCodesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/projects","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/projects/{projectId}/inventoryItems/{inventoryItemsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/projects/{projectId}/orders/{ordersId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/projects/{projectsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/regions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingListShares/{remarketingListSharesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingLists/{remarketingListsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sites/{sitesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sizes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sizes/{sizesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/subaccounts/{subaccountsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/targetableRemarketingLists/{targetableRemarketingListsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/targetingTemplates/{targetingTemplatesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRolePermissionGroups/{userRolePermissionGroupsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRolePermissions","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRolePermissions/{userRolePermissionsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRoles/{userRolesId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/videoFormats","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"dfareporting.googleapis.com","http_method":"GET","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/videoFormats/{videoFormatsId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingListShares","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/customEvents/batchinsert","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customEvents/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.customEvents.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.5/userprofiles/{userprofilesId}/creativeAssets/{creativeAssetsId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.5/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.media.upload"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/billingProfiles/{billingProfilesId}/billingAssignments","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingAssignments)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingAssignments.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/campaigns/{campaignsId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeAssets/{creativeAssetsId}/creativeAssets","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/directorySites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placements/generatetags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sizes","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"POST","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.3/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.3/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.4/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/accounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/ads","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/advertisers","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/billingProfiles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/billingProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.billingProfiles.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/campaigns","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/contentCategories","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeFields/{creativeFieldsId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creativeGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/creatives","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/eventTags","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivities","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementGroups","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placementStrategies","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/placements","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingListShares","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/remarketingLists","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/sites","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/subaccounts","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/targetingTemplates","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"dfareporting.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v4/userprofiles/{userprofilesId}/userRoles","path_regex":"^(?:/dfareporting/v4/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets/{conversationDatasetsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/generators/{generatorsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.deleteAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.deleteContexts"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/generators/{generatorsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators/{generatorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/conversations/{conversationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.conversations.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators/{generatorsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/examples/{examplesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.examples.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.versions.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/tools/{toolsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.tools.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.delete"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/validationResult","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/agent:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/answerRecords","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationDatasets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationDatasets.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationDatasets/{conversationDatasetsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationDatasets.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}/evaluations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.evaluations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.evaluations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/generators","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.generators.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/validationResult","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/answerRecords","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets/{conversationDatasetsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}/evaluations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.evaluations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.evaluations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/encryptionSpec","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionSpec)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.getEncryptionSpec"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/generators","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/generators/{generatorsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/validationResult","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/agent:search","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/answerRecords","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/generators","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.generators.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.getAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/history","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.getHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/validationResult","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:search","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:search)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.search"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/answerRecords","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/messages","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.messages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/encryptionSpec","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionSpec)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.getEncryptionSpec"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/generators","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/generators/{generatorsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/operations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs/{changelogsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/continuousTestResults","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/continuousTestResults)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.continuousTestResults.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments/{deploymentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:lookupEnvironmentHistory","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupEnvironmentHistory)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.lookupEnvironmentHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/validationResult","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generativeSettings","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generativeSettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.getGenerativeSettings"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators/{generatorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results/{resultsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:calculateCoverage","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:calculateCoverage)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.calculateCoverage"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/validationResult","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/operations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/operations","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3alpha1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/changelogs/{changelogsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changelogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.changelogs.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/conversations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.conversations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/conversations/{conversationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.conversations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/continuousTestResults","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/continuousTestResults)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.continuousTestResults.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/deployments/{deploymentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:lookupEnvironmentHistory","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupEnvironmentHistory)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.lookupEnvironmentHistory"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/validationResult","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generativeSettings","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generativeSettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.getGenerativeSettings"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators/{generatorsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/examples","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.examples.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/examples/{examplesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.examples.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/versions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.versions.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.versions.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}/results/{resultsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.results.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:calculateCoverage","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:calculateCoverage)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.calculateCoverage"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/tools","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tools)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.tools.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/tools/{toolsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.tools.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/validationResult","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/validationResult)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.getValidationResult"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.get"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/operations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.list"},{"hostname":"dialogflow.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.get"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/generators/{generatorsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/fulfillment","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/fulfillment)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.updateFulfillment"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents/{intentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts/{contextsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions/{versionsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/answerRecords/{answerRecordsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answerRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.answerRecords.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/generators/{generatorsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generativeSettings","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generativeSettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.updateGenerativeSettings"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators/{generatorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages/{pagesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generativeSettings","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generativeSettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.updateGenerativeSettings"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators/{generatorsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents/{intentsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/examples/{examplesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.examples.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes/{entityTypesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/tools/{toolsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.tools.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups/{transitionRouteGroupsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks/{webhooksId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"PATCH","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings/{securitySettingsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.patch"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/intents:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:restore","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/agent:train","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationDatasets/{conversationDatasetsId}:importConversationData","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importConversationData)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationDatasets.importConversationData"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}:deploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.deploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationModels/{conversationModelsId}:undeploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationModels.undeploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestKnowledgeAssist","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestKnowledgeAssist)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestKnowledgeAssist"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/generators","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.generators.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents:batchDelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:restore","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/agent:train","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationDatasets/{conversationDatasetsId}:importConversationData","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importConversationData)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationDatasets.importConversationData"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}/evaluations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.evaluations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}:deploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.deploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationModels/{conversationModelsId}:undeploy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationModels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationModels.undeploy"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestKnowledgeAssist","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestKnowledgeAssist)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestKnowledgeAssist"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/encryptionSpec:initialize","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionSpec:initialize)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.encryptionSpec.initialize"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/generators","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:export","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/statelessSuggestion:generate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/statelessSuggestion:generate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.statelessSuggestion.generate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/suggestions:generateStatelessSummary","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:generateStatelessSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.suggestions.generateStatelessSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/suggestions:generateStatelessSummary","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:generateStatelessSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.suggestions.generateStatelessSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/intents:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:export","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:restore","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/agent:train","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/messages:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.messages.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:compile","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:compile)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.compile"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestKnowledgeAssist","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestKnowledgeAssist)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestKnowledgeAssist"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/generators","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.generators.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.setAgent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes/{entityTypesId}/entities:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.entities.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/entityTypes:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/entityTypes:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.entityTypes.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/environments/{environmentsId}/users/{usersId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.environments.users.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents:batchDelete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/intents:batchUpdate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/intents:batchUpdate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.intents.batchUpdate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/contexts","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contexts)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.contexts.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent/versions","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:export","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:restore","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/agent:train","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agent:train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agent.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:clearSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clearSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.clearSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversationProfiles/{conversationProfilesId}:setSuggestionFeatureConfig","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversationProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setSuggestionFeatureConfig)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversationProfiles.setSuggestionFeatureConfig"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/messages:batchCreate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:batchCreate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.messages.batchCreate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestArticles","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestArticles)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestArticles"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestFaqAnswers","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestFaqAnswers)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestFaqAnswers"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestKnowledgeAssist","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestKnowledgeAssist)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestKnowledgeAssist"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}/suggestions:suggestSmartReplies","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestSmartReplies)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.suggestions.suggestSmartReplies"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/participants/{participantsId}:analyzeContent","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::analyzeContent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.participants.analyzeContent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}/suggestions:suggestConversationSummary","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:suggestConversationSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.suggestions.suggestConversationSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/conversations/{conversationsId}:complete","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.conversations.complete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/encryptionSpec:initialize","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/encryptionSpec:initialize)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.encryptionSpec.initialize"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/generators","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.generators.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents/{documentsId}:reload","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reload)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.reload"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/knowledgeBases/{knowledgeBasesId}/documents:import","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/knowledgeBases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.knowledgeBases.documents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/statelessSuggestion:generate","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/statelessSuggestion:generate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.statelessSuggestion.generate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/suggestions:generateStatelessSummary","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:generateStatelessSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.suggestions.generateStatelessSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/suggestions:generateStatelessSummary","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:generateStatelessSummary)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.suggestions.generateStatelessSummary"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/suggestions:searchKnowledge","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestions:searchKnowledge)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.suggestions.searchKnowledge"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes:import","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:start","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.start"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:stop","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.stop"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:serverStreamingDetectIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingDetectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.serverStreamingDetectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:deployFlow","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployFlow)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployFlow"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:runContinuousTest","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runContinuousTest)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.runContinuousTest"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:compareVersions","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::compareVersions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.compareVersions"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:load","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::load)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.load"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:train","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:validate","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows:import","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents:import","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:serverStreamingDetectIntent","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingDetectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.serverStreamingDetectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:submitAnswerFeedback","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::submitAnswerFeedback)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.submitAnswerFeedback"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}:run","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.run"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchDelete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchRun","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchRun)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchRun"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:import","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:export","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:restore","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:validate","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3alpha1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/entityTypes:import","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.entityTypes.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:start","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.start"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/experiments/{experimentsId}:stop","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/experiments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.experiments.stop"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}/sessions/{sessionsId}:serverStreamingDetectIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingDetectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.sessions.serverStreamingDetectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:deployFlow","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deployFlow)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.deployFlow"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/environments/{environmentsId}:runContinuousTest","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runContinuousTest)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.environments.runContinuousTest"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/pages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.pages.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/transitionRouteGroups","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.transitionRouteGroups.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:compareVersions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::compareVersions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.compareVersions"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}/versions/{versionsId}:load","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::load)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.versions.load"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:train","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::train)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.train"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows/{flowsId}:validate","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/flows:import","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/flows:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.flows.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/generators","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/generators)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.generators.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/intents:import","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/intents:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.intents.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/examples","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.examples.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/playbooks/{playbooksId}/versions","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playbooks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.playbooks.versions.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}/entityTypes","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entityTypes)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.entityTypes.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:detectIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.detectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:fulfillIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fulfillIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.fulfillIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:matchIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::matchIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.matchIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:serverStreamingDetectIntent","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::serverStreamingDetectIntent)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.serverStreamingDetectIntent"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/sessions/{sessionsId}:submitAnswerFeedback","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::submitAnswerFeedback)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.sessions.submitAnswerFeedback"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases/{testCasesId}:run","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.run"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchDelete","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchDelete)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchDelete"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:batchRun","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:batchRun)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.batchRun"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/testCases:import","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases:import)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.testCases.import"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/tools","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tools)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.tools.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/tools:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tools:export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.tools.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/transitionRouteGroups","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transitionRouteGroups)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.transitionRouteGroups.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}/webhooks","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webhooks)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.webhooks.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:export","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.export"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:restore","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.restore"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/agents/{agentsId}:validate","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.agents.validate"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.operations.cancel"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/securitySettings","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securitySettings)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.locations.securitySettings.create"},{"hostname":"dialogflow.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dialogflow","resource_name":"dialogflow.projects.operations.cancel"},{"hostname":"digitalassetlinks.googleapis.com","http_method":"GET","path_template":"/v1/assetlinks:check","path_regex":"^(?:/v1/assetlinks:check)$","service_name":"google.digitalassetlinks","resource_name":"digitalassetlinks.assetlinks.check"},{"hostname":"digitalassetlinks.googleapis.com","http_method":"GET","path_template":"/v1/statements:list","path_regex":"^(?:/v1/statements:list)$","service_name":"google.digitalassetlinks","resource_name":"digitalassetlinks.statements.list"},{"hostname":"digitalassetlinks.googleapis.com","http_method":"POST","path_template":"/v1/assetlinks:bulkCheck","path_regex":"^(?:/v1/assetlinks:bulkCheck)$","service_name":"google.digitalassetlinks","resource_name":"digitalassetlinks.assetlinks.bulkCheck"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries/{sampleQueriesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries/{sampleQueriesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.delete"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataConnector/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataConnector/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataConnector.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataConnector/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataConnector/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataConnector.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.getSiteSearchEngine"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:fetchDomainVerificationStatus","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:fetchDomainVerificationStatus)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.fetchDomainVerificationStatus"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}:completeQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completeQuery"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.getSiteSearchEngine"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}:completeQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completeQuery"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/identity_mapping_stores/{identity_mapping_storesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identity_mapping_stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.identity_mapping_stores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/identity_mapping_stores/{identity_mapping_storesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identity_mapping_stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.identity_mapping_stores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/userEvents:collect","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/aclConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aclConfig)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.getAclConfig"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataConnector/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataConnector/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataConnector.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataConnector/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataConnector/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataConnector.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}/chunks","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chunks)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.chunks.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}/chunks/{chunksId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chunks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.chunks.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}:getProcessedDocument","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getProcessedDocument)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.getProcessedDocument"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/customModels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customModels)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.customModels.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/documentProcessingConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentProcessingConfig)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.getDocumentProcessingConfig"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.getSiteSearchEngine"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:fetchDomainVerificationStatus","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:fetchDomainVerificationStatus)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.fetchDomainVerificationStatus"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:getUriPatternDocumentData","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:getUriPatternDocumentData)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.getUriPatternDocumentData"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}:completeQuery","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completeQuery"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}/chunks","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chunks)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.chunks.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}/chunks/{chunksId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/chunks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.chunks.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}:getProcessedDocument","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getProcessedDocument)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.getProcessedDocument"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/documentProcessingConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentProcessingConfig)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.getDocumentProcessingConfig"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.getSiteSearchEngine"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}:completeQuery","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completeQuery"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}:listResults","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listResults)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.listResults"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/identity_mapping_stores/{identity_mapping_storesId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identity_mapping_stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.identity_mapping_stores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/identity_mapping_stores/{identity_mapping_storesId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identity_mapping_stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.identity_mapping_stores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries/{sampleQueriesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/userEvents:collect","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataConnector/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataConnector/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataConnector.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataConnector/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataConnector/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataConnector.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/customModels","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customModels)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.customModels.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.getSiteSearchEngine"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:fetchDomainVerificationStatus","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:fetchDomainVerificationStatus)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.fetchDomainVerificationStatus"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}:completeQuery","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completeQuery"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/models/{modelsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.models.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}/answers/{answersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.answers.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.getSiteSearchEngine"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:collect","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}:completeQuery","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completeQuery"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}:listResults","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listResults)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.listResults"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries/{sampleQueriesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/userEvents:collect","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.userEvents.collect"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.list"},{"hostname":"discoveryengine.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.get"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/aclConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aclConfig)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.updateAclConfig"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/documentProcessingConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentProcessingConfig)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.updateDocumentProcessingConfig"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/documentProcessingConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documentProcessingConfig)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.updateDocumentProcessingConfig"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries/{sampleQueriesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents/{documentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls/{controlsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas/{schemasId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions/{sessionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites/{targetSitesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries/{sampleQueriesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.patch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.cancel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/completionSuggestions:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completionSuggestions.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/completionSuggestions:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completionSuggestions.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites:batchCreate)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.batchCreate"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:batchVerifyTargetSites","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:batchVerifyTargetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.batchVerifyTargetSites"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:disableAdvancedSiteSearch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:disableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.disableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:enableAdvancedSiteSearch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:enableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.enableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:recrawlUris","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:recrawlUris)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.recrawlUris"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.suggestionDenyListEntries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.suggestionDenyListEntries.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.cancel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/completionSuggestions:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completionSuggestions.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/completionSuggestions:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completionSuggestions.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites:batchCreate)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.batchCreate"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:disableAdvancedSiteSearch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:disableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.disableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:enableAdvancedSiteSearch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:enableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.enableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:recrawlUris","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:recrawlUris)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.recrawlUris"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.suggestionDenyListEntries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.suggestionDenyListEntries.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groundingConfigs/{groundingConfigsId}:check","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groundingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::check)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.groundingConfigs.check"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/rankingConfigs/{rankingConfigsId}:rank","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rankingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rank)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.rankingConfigs.rank"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/userEvents:write","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.operations.cancel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:provision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::provision)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.provision"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.cancel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/completionSuggestions:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completionSuggestions.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/completionSuggestions:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completionSuggestions.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites:batchCreate","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites:batchCreate)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.batchCreate"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:batchVerifyTargetSites","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:batchVerifyTargetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.batchVerifyTargetSites"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:disableAdvancedSiteSearch","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:disableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.disableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:enableAdvancedSiteSearch","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:enableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.enableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:recrawlUris","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:recrawlUris)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.recrawlUris"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:setUriPatternDocumentData","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:setUriPatternDocumentData)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.setUriPatternDocumentData"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.suggestionDenyListEntries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.suggestionDenyListEntries.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}:trainCustomModel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::trainCustomModel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.trainCustomModel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}:pause","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.pause"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}:resume","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.resume"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}:tune","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.tune"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.cancel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/completionSuggestions:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completionSuggestions.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/completionSuggestions:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completionSuggestions.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites:batchCreate","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites:batchCreate)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.batchCreate"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:disableAdvancedSiteSearch","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:disableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.disableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:enableAdvancedSiteSearch","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:enableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.enableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:recrawlUris","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:recrawlUris)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.recrawlUris"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.suggestionDenyListEntries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.suggestionDenyListEntries.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:purge","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/groundingConfigs/{groundingConfigsId}:check","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groundingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::check)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.groundingConfigs.check"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/rankingConfigs/{rankingConfigsId}:rank","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rankingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rank)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.rankingConfigs.rank"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/requirements:checkRequirement","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requirements:checkRequirement)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.requirements.checkRequirement"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries:import","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/userEvents:write","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}:estimateDataSize","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::estimateDataSize)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.estimateDataSize"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}:provision","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::provision)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.provision"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}:reportConsentChange","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportConsentChange)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.reportConsentChange"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.documents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.branches.operations.cancel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/completionSuggestions:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completionSuggestions.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/completionSuggestions:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.completionSuggestions.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.schemas.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites:batchCreate","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites:batchCreate)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.targetSites.batchCreate"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:batchVerifyTargetSites","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:batchVerifyTargetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.batchVerifyTargetSites"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:disableAdvancedSiteSearch","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:disableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.disableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:enableAdvancedSiteSearch","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:enableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.enableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/siteSearchEngine:recrawlUris","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:recrawlUris)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.siteSearchEngine.recrawlUris"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.suggestionDenyListEntries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.suggestionDenyListEntries.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/dataStores/{dataStoresId}:trainCustomModel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::trainCustomModel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.dataStores.trainCustomModel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/controls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}/sessions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}:pause","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.pause"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}:resume","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.resume"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/collections/{collectionsId}/engines/{enginesId}:tune","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.collections.engines.tune"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/documents:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.documents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/branches/{branchesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.branches.operations.cancel"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/completionSuggestions:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completionSuggestions.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/completionSuggestions:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionSuggestions:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.completionSuggestions.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/controls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.controls.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/conversations/{conversationsId}:converse","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::converse)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.conversations.converse"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/schemas","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.schemas.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:answer","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::answer)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.answer"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:recommend","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::recommend)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.recommend"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.servingConfigs.search"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/sessions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.sessions.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine/targetSites:batchCreate","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine/targetSites:batchCreate)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.targetSites.batchCreate"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:disableAdvancedSiteSearch","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:disableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.disableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:enableAdvancedSiteSearch","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:enableAdvancedSiteSearch)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.enableAdvancedSiteSearch"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/siteSearchEngine:recrawlUris","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/siteSearchEngine:recrawlUris)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.siteSearchEngine.recrawlUris"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.suggestionDenyListEntries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/suggestionDenyListEntries:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suggestionDenyListEntries:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.suggestionDenyListEntries.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:purge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.purge"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/dataStores/{dataStoresId}/userEvents:write","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.dataStores.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.evaluations.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/groundingConfigs/{groundingConfigsId}:check","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groundingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::check)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.groundingConfigs.check"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/rankingConfigs/{rankingConfigsId}:rank","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rankingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rank)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.rankingConfigs.rank"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.create"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/sampleQuerySets/{sampleQuerySetsId}/sampleQueries:import","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQuerySets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sampleQueries:import)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.sampleQuerySets.sampleQueries.import"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/userEvents:write","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.locations.userEvents.write"},{"hostname":"discoveryengine.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}:provision","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::provision)$","service_name":"google.discoveryengine","resource_name":"discoveryengine.projects.provision"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations/{assignedLocationsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords/{negativeKeywordsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources/{assignedInventorySourcesId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v1/users/{usersId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations/{assignedLocationsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords/{negativeKeywordsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources/{assignedInventorySourcesId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v2/users/{usersId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertiserId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations/{assignedLocationsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords/{negativeKeywordsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v3/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources/{assignedInventorySourcesId}","path_regex":"^(?:/v3/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/partners/{partnerId}/channels/{channelsId}/sites/{sitesId}","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"DELETE","path_template":"/v3/users/{usersId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.delete"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/download/{downloadId}","path_regex":"^(?:/download/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.download"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers","path_regex":"^(?:/v1/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}:bulkListCampaignAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListCampaignAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.bulkListCampaignAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/channels","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/channels/{channelsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}:bulkListInsertionOrderAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListInsertionOrderAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.bulkListInsertionOrderAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/invoices","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/invoices:lookupInvoiceCurrency","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices:lookupInvoiceCurrency)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.lookupInvoiceCurrency"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}:bulkListLineItemAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListLineItemAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkListLineItemAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/locationLists/{locationListsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}:audit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::audit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.audit"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/advertisers/{advertisersId}:bulkListAdvertiserAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkListAdvertiserAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.bulkListAdvertiserAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/combinedAudiences","path_regex":"^(?:/v1/combinedAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/combinedAudiences/{combinedAudiencesId}","path_regex":"^(?:/v1/combinedAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms","path_regex":"^(?:/v1/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts/{scriptsId}","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}:uploadScript","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::uploadScript)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.uploadScript"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customLists","path_regex":"^(?:/v1/customLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/customLists/{customListsId}","path_regex":"^(?:/v1/customLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/firstAndThirdPartyAudiences","path_regex":"^(?:/v1/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v1/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/floodlightGroups/{floodlightGroupsId}","path_regex":"^(?:/v1/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/googleAudiences","path_regex":"^(?:/v1/googleAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/googleAudiences/{googleAudiencesId}","path_regex":"^(?:/v1/googleAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/guaranteedOrders","path_regex":"^(?:/v1/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v1/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySourceGroups","path_regex":"^(?:/v1/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySources","path_regex":"^(?:/v1/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v1/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners","path_regex":"^(?:/v1/partners)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/channels","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/channels/{channelsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/targetingTypes/{targetingTypesId}/targetingOptions","path_regex":"^(?:/v1/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/targetingTypes/{targetingTypesId}/targetingOptions/{targetingOptionsId}","path_regex":"^(?:/v1/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/users","path_regex":"^(?:/v1/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1beta/sdfdownloadtask/operations/{operationsId}","path_regex":"^(?:/v1beta/sdfdownloadtask/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtask.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1beta/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1beta/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1beta2/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1beta2/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v1dev/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v1dev/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers","path_regex":"^(?:/v2/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}:listAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/channels","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/channels/{channelsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}:listAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/invoices","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/invoices:lookupInvoiceCurrency","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices:lookupInvoiceCurrency)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.lookupInvoiceCurrency"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/lineItems:bulkListAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkListAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkListAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/locationLists/{locationListsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroupAds","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroupAds)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroupAds.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroupAds/{youtubeAdGroupAdsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroupAds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroupAds.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups/{youtubeAdGroupsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups/{youtubeAdGroupsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups/{youtubeAdGroupsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}/youtubeAdGroups:bulkListAdGroupAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/youtubeAdGroups:bulkListAdGroupAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.youtubeAdGroups.bulkListAdGroupAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}:audit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::audit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.audit"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/advertisers/{advertisersId}:listAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/combinedAudiences","path_regex":"^(?:/v2/combinedAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/combinedAudiences/{combinedAudiencesId}","path_regex":"^(?:/v2/combinedAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms","path_regex":"^(?:/v2/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts/{scriptsId}","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}:uploadScript","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::uploadScript)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.uploadScript"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customLists","path_regex":"^(?:/v2/customLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/customLists/{customListsId}","path_regex":"^(?:/v2/customLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/firstAndThirdPartyAudiences","path_regex":"^(?:/v2/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v2/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/floodlightGroups/{floodlightGroupsId}","path_regex":"^(?:/v2/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/floodlightGroups/{floodlightGroupsId}/floodlightActivities","path_regex":"^(?:/v2/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.floodlightActivities.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/floodlightGroups/{floodlightGroupsId}/floodlightActivities/{floodlightActivitiesId}","path_regex":"^(?:/v2/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.floodlightActivities.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/googleAudiences","path_regex":"^(?:/v2/googleAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/googleAudiences/{googleAudiencesId}","path_regex":"^(?:/v2/googleAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/guaranteedOrders","path_regex":"^(?:/v2/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v2/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySourceGroups","path_regex":"^(?:/v2/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySources","path_regex":"^(?:/v2/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v2/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners","path_regex":"^(?:/v2/partners)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/channels","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/channels/{channelsId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v2/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/targetingTypes/{targetingTypesId}/targetingOptions","path_regex":"^(?:/v2/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/targetingTypes/{targetingTypesId}/targetingOptions/{targetingOptionsId}","path_regex":"^(?:/v2/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/users","path_regex":"^(?:/v2/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v2/users/{usersId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers","path_regex":"^(?:/v3/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/adGroupAds","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adGroupAds)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.adGroupAds.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/adGroupAds/{adGroupAdsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adGroupAds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.adGroupAds.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/adGroups","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.adGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/adGroups/{adGroupsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.adGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/adGroups/{adGroupsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.adGroups.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/adGroups/{adGroupsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.adGroups.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/adGroups:bulkListAdGroupAssignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adGroups:bulkListAdGroupAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.adGroups.bulkListAdGroupAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/campaigns/{campaignsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/campaigns/{campaignsId}:listAssignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/channels","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/channels/{channelsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/channels/{channelsId}/sites","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}:listAssignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/invoices","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/invoices:lookupInvoiceCurrency","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invoices:lookupInvoiceCurrency)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.invoices.lookupInvoiceCurrency"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/lineItems:bulkListAssignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkListAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkListAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/locationLists/{locationListsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}:audit","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::audit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.audit"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/advertisers/{advertisersId}:listAssignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.listAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/combinedAudiences","path_regex":"^(?:/v3/combinedAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/combinedAudiences/{combinedAudiencesId}","path_regex":"^(?:/v3/combinedAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.combinedAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms","path_regex":"^(?:/v3/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}/rules","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.rules.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}/rules/{rulesId}","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.rules.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts/{scriptsId}","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}:uploadRules","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::uploadRules)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.uploadRules"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}:uploadScript","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::uploadScript)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.uploadScript"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customLists","path_regex":"^(?:/v3/customLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/customLists/{customListsId}","path_regex":"^(?:/v3/customLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customLists.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/firstAndThirdPartyAudiences","path_regex":"^(?:/v3/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v3/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/floodlightGroups/{floodlightGroupsId}","path_regex":"^(?:/v3/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/floodlightGroups/{floodlightGroupsId}/floodlightActivities","path_regex":"^(?:/v3/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.floodlightActivities.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/floodlightGroups/{floodlightGroupsId}/floodlightActivities/{floodlightActivitiesId}","path_regex":"^(?:/v3/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.floodlightActivities.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/googleAudiences","path_regex":"^(?:/v3/googleAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/googleAudiences/{googleAudiencesId}","path_regex":"^(?:/v3/googleAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.googleAudiences.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/guaranteedOrders","path_regex":"^(?:/v3/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v3/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/inventorySourceGroups","path_regex":"^(?:/v3/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/inventorySourceGroups/{inventorySourceGroupsId}","path_regex":"^(?:/v3/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v3/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/inventorySources","path_regex":"^(?:/v3/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v3/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/partners","path_regex":"^(?:/v3/partners)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/partners/{partnersId}","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/partners/{partnersId}/channels","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/partners/{partnersId}/channels/{channelsId}","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/partners/{partnersId}/channels/{channelsId}/sites","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions/{assignedTargetingOptionsId}","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v3/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/targetingTypes/{targetingTypesId}/targetingOptions","path_regex":"^(?:/v3/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/targetingTypes/{targetingTypesId}/targetingOptions/{targetingOptionsId}","path_regex":"^(?:/v3/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/users","path_regex":"^(?:/v3/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.list"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v3/users/{usersId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.get"},{"hostname":"displayvideo.googleapis.com","http_method":"GET","path_template":"/v4/sdfdownloadtasks/operations/{operationsId}","path_regex":"^(?:/v4/sdfdownloadtasks/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.operations.get"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/channels/{channelId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/locationLists/{locationListId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListId}","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v1/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/floodlightGroups/{floodlightGroupId}","path_regex":"^(?:/v1/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v1/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupId}","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v1/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/partners/{partnersId}/channels/{channelId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v1/users/{usersId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/channels/{channelId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/locationLists/{locationListId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListId}","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v2/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/floodlightGroups/{floodlightGroupId}","path_regex":"^(?:/v2/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v2/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupId}","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v2/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/partners/{partnersId}/channels/{channelId}","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v2/users/{usersId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}/campaigns/{campaignsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}/channels/{channelId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}/creatives/{creativesId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}/locationLists/{locationListId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/advertisers/{advertisersId}/negativeKeywordLists/{negativeKeywordListId}","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}","path_regex":"^(?:/v3/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/floodlightGroups/{floodlightGroupId}","path_regex":"^(?:/v3/floodlightGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.floodlightGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/guaranteedOrders/{guaranteedOrdersId}","path_regex":"^(?:/v3/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/inventorySourceGroups/{inventorySourceGroupId}","path_regex":"^(?:/v3/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/inventorySources/{inventorySourcesId}","path_regex":"^(?:/v3/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/partners/{partnersId}/channels/{channelId}","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"PATCH","path_template":"/v3/users/{usersId}","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.users.patch"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/media/{mediaId}","path_regex":"^(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/media/{mediaId}","path_regex":"^(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/media/{mediaId}","path_regex":"^(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/media/{mediaId}","path_regex":"^(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.displayvideo","resource_name":"displayvideo.media.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers","path_regex":"^(?:/v1/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/locationLists/{locationListsId}/assignedLocations:bulkEdit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:bulkEdit","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:replace","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/assets","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.assets.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/channels","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems/{lineItemsId}:bulkEditLineItemAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditLineItemAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkEditLineItemAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/lineItems:generateDefault","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:generateDefault)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.generateDefault"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:activate","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.activate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:deactivate","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.deactivate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/advertisers/{advertisersId}:bulkEditAdvertiserAssignedTargetingOptions","path_regex":"^(?:/v1/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditAdvertiserAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.bulkEditAdvertiserAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/customBiddingAlgorithms","path_regex":"^(?:/v1/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v1/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/firstAndThirdPartyAudiences","path_regex":"^(?:/v1/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}:editCustomerMatchMembers","path_regex":"^(?:/v1/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editCustomerMatchMembers)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.editCustomerMatchMembers"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/guaranteedOrders","path_regex":"^(?:/v1/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/guaranteedOrders/{guaranteedOrdersId}:editGuaranteedOrderReadAccessors","path_regex":"^(?:/v1/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editGuaranteedOrderReadAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.editGuaranteedOrderReadAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySourceGroups","path_regex":"^(?:/v1/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources:bulkEdit","path_regex":"^(?:/v1/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySources","path_regex":"^(?:/v1/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/inventorySources/{inventorySourcesId}:editInventorySourceReadWriteAccessors","path_regex":"^(?:/v1/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editInventorySourceReadWriteAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.editInventorySourceReadWriteAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnerId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/channels","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}:bulkEditPartnerAssignedTargetingOptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditPartnerAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.bulkEditPartnerAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/sdfdownloadtasks","path_regex":"^(?:/v1/sdfdownloadtasks)$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/targetingTypes/{targetingTypesId}/targetingOptions:search","path_regex":"^(?:/v1/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions:search)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.search"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/users","path_regex":"^(?:/v1/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}:bulkEditAssignedUserRoles","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditAssignedUserRoles)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.bulkEditAssignedUserRoles"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers","path_regex":"^(?:/v2/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/locationLists/{locationListsId}/assignedLocations:bulkEdit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:bulkEdit","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:replace","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/assets","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.assets.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/channels","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems/{lineItemsId}:duplicate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::duplicate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.duplicate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems:bulkEditAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkEditAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkEditAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems:bulkUpdate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkUpdate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkUpdate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/lineItems:generateDefault","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:generateDefault)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.generateDefault"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/manualTriggers","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:activate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.activate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/manualTriggers/{manualTriggersId}:deactivate","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/manualTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.manualTriggers.deactivate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/advertisers/{advertisersId}:editAssignedTargetingOptions","path_regex":"^(?:/v2/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.editAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/customBiddingAlgorithms","path_regex":"^(?:/v2/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v2/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/firstAndThirdPartyAudiences","path_regex":"^(?:/v2/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}:editCustomerMatchMembers","path_regex":"^(?:/v2/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editCustomerMatchMembers)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.editCustomerMatchMembers"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/guaranteedOrders","path_regex":"^(?:/v2/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/guaranteedOrders/{guaranteedOrdersId}:editGuaranteedOrderReadAccessors","path_regex":"^(?:/v2/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editGuaranteedOrderReadAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.editGuaranteedOrderReadAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySourceGroups","path_regex":"^(?:/v2/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources:bulkEdit","path_regex":"^(?:/v2/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySources","path_regex":"^(?:/v2/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/inventorySources/{inventorySourcesId}:editInventorySourceReadWriteAccessors","path_regex":"^(?:/v2/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editInventorySourceReadWriteAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.editInventorySourceReadWriteAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnerId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnersId}/channels","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/partners/{partnersId}:editAssignedTargetingOptions","path_regex":"^(?:/v2/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.editAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/sdfdownloadtasks","path_regex":"^(?:/v2/sdfdownloadtasks)$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/targetingTypes/{targetingTypesId}/targetingOptions:search","path_regex":"^(?:/v2/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions:search)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.search"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/users","path_regex":"^(?:/v2/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v2/users/{usersId}:bulkEditAssignedUserRoles","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditAssignedUserRoles)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.bulkEditAssignedUserRoles"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers","path_regex":"^(?:/v3/advertisers)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/channels/{channelsId}/sites","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/locationLists/{locationListId}/assignedLocations","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/locationLists/{locationListsId}/assignedLocations:bulkEdit","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedLocations:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.assignedLocations.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:bulkEdit","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertiserId}/negativeKeywordLists/{negativeKeywordListsId}/negativeKeywords:replace","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywords:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.negativeKeywords.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/assets","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.assets.upload"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/campaigns","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.campaigns.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/channels","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/creatives","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.creatives.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/insertionOrders","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/insertionOrders/{insertionOrdersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insertionOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.insertionOrders.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/lineItems","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/lineItems/{lineItemsId}:duplicate","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::duplicate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.duplicate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/lineItems:bulkEditAssignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkEditAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkEditAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/lineItems:bulkUpdate","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:bulkUpdate)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.bulkUpdate"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/lineItems:generateDefault","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lineItems:generateDefault)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.lineItems.generateDefault"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/locationLists","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locationLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.locationLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/negativeKeywordLists","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/negativeKeywordLists)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.negativeKeywordLists.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/advertisers/{advertisersId}:editAssignedTargetingOptions","path_regex":"^(?:/v3/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.advertisers.editAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/customBiddingAlgorithms","path_regex":"^(?:/v3/customBiddingAlgorithms)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}/rules","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.rules.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/customBiddingAlgorithms/{customBiddingAlgorithmsId}/scripts","path_regex":"^(?:/v3/customBiddingAlgorithms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scripts)$","service_name":"google.displayvideo","resource_name":"displayvideo.customBiddingAlgorithms.scripts.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/firstAndThirdPartyAudiences","path_regex":"^(?:/v3/firstAndThirdPartyAudiences)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/firstAndThirdPartyAudiences/{firstAndThirdPartyAudiencesId}:editCustomerMatchMembers","path_regex":"^(?:/v3/firstAndThirdPartyAudiences/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editCustomerMatchMembers)$","service_name":"google.displayvideo","resource_name":"displayvideo.firstAndThirdPartyAudiences.editCustomerMatchMembers"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/guaranteedOrders","path_regex":"^(?:/v3/guaranteedOrders)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/guaranteedOrders/{guaranteedOrdersId}:editGuaranteedOrderReadAccessors","path_regex":"^(?:/v3/guaranteedOrders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editGuaranteedOrderReadAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.guaranteedOrders.editGuaranteedOrderReadAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/inventorySourceGroups","path_regex":"^(?:/v3/inventorySourceGroups)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources","path_regex":"^(?:/v3/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/inventorySourceGroups/{inventorySourceGroupsId}/assignedInventorySources:bulkEdit","path_regex":"^(?:/v3/inventorySourceGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedInventorySources:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySourceGroups.assignedInventorySources.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/inventorySources","path_regex":"^(?:/v3/inventorySources)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/inventorySources/{inventorySourcesId}:editInventorySourceReadWriteAccessors","path_regex":"^(?:/v3/inventorySources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editInventorySourceReadWriteAccessors)$","service_name":"google.displayvideo","resource_name":"displayvideo.inventorySources.editInventorySourceReadWriteAccessors"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/partners/{partnerId}/channels/{channelsId}/sites","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/partners/{partnerId}/channels/{channelsId}/sites:bulkEdit","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:bulkEdit)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.bulkEdit"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/partners/{partnerId}/channels/{channelsId}/sites:replace","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites:replace)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.sites.replace"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/partners/{partnersId}/channels","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.channels.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/partners/{partnersId}/targetingTypes/{targetingTypesId}/assignedTargetingOptions","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.targetingTypes.assignedTargetingOptions.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/partners/{partnersId}:editAssignedTargetingOptions","path_regex":"^(?:/v3/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::editAssignedTargetingOptions)$","service_name":"google.displayvideo","resource_name":"displayvideo.partners.editAssignedTargetingOptions"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/sdfdownloadtasks","path_regex":"^(?:/v3/sdfdownloadtasks)$","service_name":"google.displayvideo","resource_name":"displayvideo.sdfdownloadtasks.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/targetingTypes/{targetingTypesId}/targetingOptions:search","path_regex":"^(?:/v3/targetingTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingOptions:search)$","service_name":"google.displayvideo","resource_name":"displayvideo.targetingTypes.targetingOptions.search"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/users","path_regex":"^(?:/v3/users)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.create"},{"hostname":"displayvideo.googleapis.com","http_method":"POST","path_template":"/v3/users/{usersId}:bulkEditAssignedUserRoles","path_regex":"^(?:/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkEditAssignedUserRoles)$","service_name":"google.displayvideo","resource_name":"displayvideo.users.bulkEditAssignedUserRoles"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.connections.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/discoveryConfigs/{discoveryConfigsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.discoveryConfigs.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/fileStoreDataProfiles/{fileStoreDataProfilesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fileStoreDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.fileStoreDataProfiles.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/tableDataProfiles/{tableDataProfilesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tableDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.tableDataProfiles.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.connections.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/discoveryConfigs/{discoveryConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.discoveryConfigs.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/fileStoreDataProfiles/{fileStoreDataProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fileStoreDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.fileStoreDataProfiles.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/tableDataProfiles/{tableDataProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tableDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.tableDataProfiles.delete"},{"hostname":"dlp.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.delete"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/infoTypes","path_regex":"^(?:/v2/infoTypes)$","service_name":"google.dlp","resource_name":"dlp.infoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/locations/{locationsId}/infoTypes","path_regex":"^(?:/v2/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/infoTypes)$","service_name":"google.dlp","resource_name":"dlp.locations.infoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/columnDataProfiles","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columnDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.columnDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/columnDataProfiles/{columnDataProfilesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columnDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.columnDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/connections","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.connections.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.connections.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/connections:search","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections:search)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.connections.search"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/discoveryConfigs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.discoveryConfigs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/discoveryConfigs/{discoveryConfigsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.discoveryConfigs.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/dlpJobs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.dlpJobs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/fileStoreDataProfiles","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fileStoreDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.fileStoreDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/fileStoreDataProfiles/{fileStoreDataProfilesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fileStoreDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.fileStoreDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/projectDataProfiles","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.projectDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/projectDataProfiles/{projectDataProfilesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.projectDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/tableDataProfiles","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tableDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.tableDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/tableDataProfiles/{tableDataProfilesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tableDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.tableDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/columnDataProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columnDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.columnDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/columnDataProfiles/{columnDataProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columnDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.columnDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.connections.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.connections.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections:search)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.connections.search"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/discoveryConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.discoveryConfigs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/discoveryConfigs/{discoveryConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.discoveryConfigs.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/fileStoreDataProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fileStoreDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.fileStoreDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/fileStoreDataProfiles/{fileStoreDataProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fileStoreDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.fileStoreDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/projectDataProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.projectDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/projectDataProfiles/{projectDataProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projectDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.projectDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/tableDataProfiles","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tableDataProfiles)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.tableDataProfiles.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/tableDataProfiles/{tableDataProfilesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tableDataProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.tableDataProfiles.get"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.list"},{"hostname":"dlp.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.get"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.connections.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/discoveryConfigs/{discoveryConfigsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.discoveryConfigs.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.connections.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates/{deidentifyTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/discoveryConfigs/{discoveryConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.discoveryConfigs.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates/{inspectTemplatesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/storedInfoTypes/{storedInfoTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.patch"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/connections","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.connections.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/discoveryConfigs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.discoveryConfigs.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.jobTriggers.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.locations.storedInfoTypes.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/storedInfoTypes","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.organizations.storedInfoTypes.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/content:deidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:deidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.content.deidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/content:inspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:inspect)$","service_name":"google.dlp","resource_name":"dlp.projects.content.inspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/content:reidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:reidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.content.reidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/dlpJobs/{dlpJobsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dlp","resource_name":"dlp.projects.dlpJobs.cancel"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/image:redact","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/image:redact)$","service_name":"google.dlp","resource_name":"dlp.projects.image.redact"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/jobTriggers/{jobTriggersId}:activate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.dlp","resource_name":"dlp.projects.jobTriggers.activate"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.connections.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/content:deidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:deidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.content.deidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/content:inspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:inspect)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.content.inspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/content:reidentify","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content:reidentify)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.content.reidentify"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/deidentifyTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deidentifyTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.deidentifyTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/discoveryConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryConfigs)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.discoveryConfigs.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.cancel"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}:finish","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::finish)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.finish"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/dlpJobs/{dlpJobsId}:hybridInspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dlpJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::hybridInspect)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.dlpJobs.hybridInspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/image:redact","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/image:redact)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.image.redact"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/inspectTemplates","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inspectTemplates)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.inspectTemplates.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}:activate","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.activate"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobTriggers/{jobTriggersId}:hybridInspect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTriggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::hybridInspect)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.jobTriggers.hybridInspect"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.locations.storedInfoTypes.create"},{"hostname":"dlp.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/storedInfoTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storedInfoTypes)$","service_name":"google.dlp","resource_name":"dlp.projects.storedInfoTypes.create"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.delete"},{"hostname":"dns.googleapis.com","http_method":"DELETE","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.delete"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/policies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/policies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/policies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.projects.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/changes/{changeId}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.changes.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/dnsKeys","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys)$","service_name":"google.dns","resource_name":"dns.dnsKeys.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/dnsKeys/{dnsKeyId}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.dnsKeys.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/operations","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/operations/{operation}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZoneOperations.get"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/policies","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.list"},{"hostname":"dns.googleapis.com","http_method":"GET","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.get"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets/{name}/{type}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.patch"},{"hostname":"dns.googleapis.com","http_method":"PATCH","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.patch"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{projectsId}/managedZones/{managedZonesId}:getIamPolicy","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.getIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{projectsId}/managedZones/{managedZonesId}:setIamPolicy","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.setIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{projectsId}/managedZones/{managedZonesId}:testIamPermissions","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dns","resource_name":"dns.managedZones.testIamPermissions"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/managedZones","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/policies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{projectsId}/managedZones/{managedZonesId}:getIamPolicy","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.getIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{projectsId}/managedZones/{managedZonesId}:setIamPolicy","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.dns","resource_name":"dns.managedZones.setIamPolicy"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{projectsId}/managedZones/{managedZonesId}:testIamPermissions","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.dns","resource_name":"dns.managedZones.testIamPermissions"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/managedZones","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/policies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/responsePolicies","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}/rrsets","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rrsets)$","service_name":"google.dns","resource_name":"dns.resourceRecordSets.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/policies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies)$","service_name":"google.dns","resource_name":"dns.responsePolicies.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2beta1/projects/{project}/managedZones","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones)$","service_name":"google.dns","resource_name":"dns.managedZones.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}/changes","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changes)$","service_name":"google.dns","resource_name":"dns.changes.create"},{"hostname":"dns.googleapis.com","http_method":"POST","path_template":"/dns/v2beta1/projects/{project}/policies","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.dns","resource_name":"dns.policies.create"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v1beta2/projects/{project}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/policies/{policy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicies.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2/projects/{project}/locations/{location}/responsePolicies/{responsePolicy}/rules/{responsePolicyRule}","path_regex":"^(?:/dns/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responsePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.responsePolicyRules.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2beta1/projects/{project}/managedZones/{managedZone}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.managedZones.update"},{"hostname":"dns.googleapis.com","http_method":"PUT","path_template":"/dns/v2beta1/projects/{project}/policies/{policy}","path_regex":"^(?:/dns/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dns","resource_name":"dns.policies.update"},{"hostname":"docs.googleapis.com","http_method":"GET","path_template":"/v1/documents/{documentId}","path_regex":"^(?:/v1/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.docs","resource_name":"docs.documents.get"},{"hostname":"docs.googleapis.com","http_method":"POST","path_template":"/v1/documents","path_regex":"^(?:/v1/documents)$","service_name":"google.docs","resource_name":"docs.documents.create"},{"hostname":"docs.googleapis.com","http_method":"POST","path_template":"/v1/documents/{documentId}:batchUpdate","path_regex":"^(?:/v1/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.docs","resource_name":"docs.documents.batchUpdate"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.operations.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.delete"},{"hostname":"documentai.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.delete"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processorTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processorTypes/{processorTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:fetchProcessorTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchProcessorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.fetchProcessorTypes"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processorTypes","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processorTypes/{processorTypesId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processorTypes.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/dataset/datasetSchema","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset/datasetSchema)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.dataset.getDatasetSchema"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/dataset:getDocument","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset:getDocument)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.dataset.getDocument"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.list"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluations.get"},{"hostname":"documentai.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}:fetchProcessorTypes","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchProcessorTypes)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.fetchProcessorTypes"},{"hostname":"documentai.googleapis.com","http_method":"PATCH","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/dataset","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.updateDataset"},{"hostname":"documentai.googleapis.com","http_method":"PATCH","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/dataset/datasetSchema","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset/datasetSchema)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.dataset.updateDatasetSchema"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.cancel"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.create"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/humanReviewConfig:reviewDocument","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/humanReviewConfig:reviewDocument)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.humanReviewConfig.reviewDocument"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:batchProcess","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:deploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.deploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:evaluateProcessorVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluateProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:process","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:undeploy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.undeploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions:train","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions:train)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.train"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:batchProcess","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.disable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.enable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:process","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:setDefaultProcessorVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.setDefaultProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/documents:batchProcess","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.documents.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/documents:process","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:process)$","service_name":"google.documentai","resource_name":"documentai.projects.documents.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/documents:batchProcess","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.documents.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/documents:process","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.documents.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.operations.cancel"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.create"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/dataset:batchDeleteDocuments","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset:batchDeleteDocuments)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.dataset.batchDeleteDocuments"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/dataset:importDocuments","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset:importDocuments)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.dataset.importDocuments"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/dataset:listDocuments","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset:listDocuments)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.dataset.listDocuments"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/humanReviewConfig:reviewDocument","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/humanReviewConfig:reviewDocument)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.humanReviewConfig.reviewDocument"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:batchProcess","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:deploy","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.deploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:evaluateProcessorVersion","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.evaluateProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:process","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions/{processorVersionsId}:undeploy","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeploy)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.undeploy"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions:importProcessorVersion","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions:importProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.importProcessorVersion"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}/processorVersions:train","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processorVersions:train)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.processorVersions.train"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:batchProcess","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchProcess)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.batchProcess"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:disable","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.disable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:enable","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.enable"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:process","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::process)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.process"},{"hostname":"documentai.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/locations/{locationsId}/processors/{processorsId}:setDefaultProcessorVersion","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/processors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultProcessorVersion)$","service_name":"google.documentai","resource_name":"documentai.projects.locations.processors.setDefaultProcessorVersion"},{"hostname":"domains.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.delete"},{"hostname":"domains.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.delete"},{"hostname":"domains.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.delete"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.domains","resource_name":"domains.projects.locations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.getIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveAuthorizationCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveGoogleDomainsDnsRecords","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveGoogleDomainsDnsRecords)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveGoogleDomainsDnsRecords"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveGoogleDomainsForwardingConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveGoogleDomainsForwardingConfig)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveGoogleDomainsForwardingConfig"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveImportableDomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveImportableDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveImportableDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveRegisterParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveRegisterParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveRegisterParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveTransferParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveTransferParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveTransferParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:searchDomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:searchDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.searchDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.domains","resource_name":"domains.projects.locations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.getIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveAuthorizationCode","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveGoogleDomainsDnsRecords","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveGoogleDomainsDnsRecords)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveGoogleDomainsDnsRecords"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveGoogleDomainsForwardingConfig","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveGoogleDomainsForwardingConfig)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveGoogleDomainsForwardingConfig"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:retrieveImportableDomains","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveImportableDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveImportableDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:retrieveRegisterParameters","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveRegisterParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveRegisterParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:retrieveTransferParameters","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveTransferParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveTransferParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:searchDomains","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:searchDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.searchDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.domains","resource_name":"domains.projects.locations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.operations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.list"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.get"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.getIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveAuthorizationCode","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveGoogleDomainsDnsRecords","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveGoogleDomainsDnsRecords)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveGoogleDomainsDnsRecords"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:retrieveGoogleDomainsForwardingConfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveGoogleDomainsForwardingConfig)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveGoogleDomainsForwardingConfig"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveImportableDomains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveImportableDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveImportableDomains"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveRegisterParameters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveRegisterParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveRegisterParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:retrieveTransferParameters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:retrieveTransferParameters)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.retrieveTransferParameters"},{"hostname":"domains.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:searchDomains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:searchDomains)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.searchDomains"},{"hostname":"domains.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.patch"},{"hostname":"domains.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.patch"},{"hostname":"domains.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.patch"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureContactSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureContactSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureContactSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureDnsSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureDnsSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureDnsSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureManagementSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureManagementSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureManagementSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.export"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:initiatePushTransfer","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initiatePushTransfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.initiatePushTransfer"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:renewDomain","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::renewDomain)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.renewDomain"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:resetAuthorizationCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.resetAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.setIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.testIamPermissions"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:import)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.import"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:register","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:register)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.register"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/registrations:transfer","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:transfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.transfer"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureContactSettings","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureContactSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureContactSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureDnsSettings","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureDnsSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureDnsSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureManagementSettings","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureManagementSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureManagementSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:export","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.export"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:initiatePushTransfer","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initiatePushTransfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.initiatePushTransfer"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:renewDomain","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::renewDomain)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.renewDomain"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:resetAuthorizationCode","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.resetAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.setIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.testIamPermissions"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:import","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:import)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.import"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:register","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:register)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.register"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/registrations:transfer","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:transfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.transfer"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureContactSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureContactSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureContactSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureDnsSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureDnsSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureDnsSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:configureManagementSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureManagementSettings)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.configureManagementSettings"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.export"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:initiatePushTransfer","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initiatePushTransfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.initiatePushTransfer"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:renewDomain","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::renewDomain)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.renewDomain"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:resetAuthorizationCode","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAuthorizationCode)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.resetAuthorizationCode"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.setIamPolicy"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations/{registrationsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.testIamPermissions"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:import)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.import"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:register","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:register)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.register"},{"hostname":"domains.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/registrations:transfer","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/registrations:transfer)$","service_name":"google.domains","resource_name":"domains.projects.locations.registrations.transfer"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/autnum/{autnumId}","path_regex":"^(?:/v1/autnum/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.autnum.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/domain/{domainId}","path_regex":"^(?:/v1/domain/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.domain.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/domains","path_regex":"^(?:/v1/domains)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getDomains"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/entities","path_regex":"^(?:/v1/entities)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getEntities"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/entity/{entityId}","path_regex":"^(?:/v1/entity/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.entity.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/help","path_regex":"^(?:/v1/help)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getHelp"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/ip","path_regex":"^(?:/v1/ip)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getIp"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/ip/{ipId}/{ipId1}","path_regex":"^(?:/v1/ip/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.ip.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/nameserver/{nameserverId}","path_regex":"^(?:/v1/nameserver/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.domainsrdap","resource_name":"domainsrdap.nameserver.get"},{"hostname":"domainsrdap.googleapis.com","http_method":"GET","path_template":"/v1/nameservers","path_regex":"^(?:/v1/nameservers)$","service_name":"google.domainsrdap","resource_name":"domainsrdap.getNameservers"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"DELETE","path_template":"/doubleclickbidmanager/v1.1/query/{queryId}","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.deletequery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"DELETE","path_template":"/v2/queries/{queryId}","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.delete"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/doubleclickbidmanager/v1.1/queries","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/queries)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.listqueries"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/doubleclickbidmanager/v1.1/queries/{queryId}/reports","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.reports.listreports"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/doubleclickbidmanager/v1.1/query/{queryId}","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.getquery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries","path_regex":"^(?:/v2/queries)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.list"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries/{queryId}","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.get"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries/{queryId}/reports","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.reports.list"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"GET","path_template":"/v2/queries/{queryId}/reports/{reportId}","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.reports.get"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/doubleclickbidmanager/v1.1/query","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.createquery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/doubleclickbidmanager/v1.1/query/{queryId}","path_regex":"^(?:/doubleclickbidmanager/v1\\.1/query/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.runquery"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/v2/queries","path_regex":"^(?:/v2/queries)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.create"},{"hostname":"doubleclickbidmanager.googleapis.com","http_method":"POST","path_template":"/v2/queries/{queryId}:run","path_regex":"^(?:/v2/queries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.doubleclickbidmanager","resource_name":"doubleclickbidmanager.queries.run"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/agency/{agencyId}/advertiser/{advertiserId}/engine/{engineAccountId}/conversion","path_regex":"^(?:/doubleclicksearch/v2/agency/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/engine/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.get"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/agency/{agencyId}/advertiser/{advertiserId}/idmapping","path_regex":"^(?:/doubleclicksearch/v2/agency/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/idmapping)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.getIdMappingFile"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/agency/{agencyId}/advertiser/{advertiserId}/savedcolumns","path_regex":"^(?:/doubleclicksearch/v2/agency/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiser/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedcolumns)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.savedColumns.list"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/customer/{customerId}/conversion","path_regex":"^(?:/doubleclicksearch/v2/customer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.getByCustomerId"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/reports/{reportId}","path_regex":"^(?:/doubleclicksearch/v2/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.get"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"GET","path_template":"/doubleclicksearch/v2/reports/{reportId}/files/{reportFragment}","path_regex":"^(?:/doubleclicksearch/v2/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.getFile"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/conversion","path_regex":"^(?:/doubleclicksearch/v2/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.insert"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/conversion/updateAvailability","path_regex":"^(?:/doubleclicksearch/v2/conversion/updateAvailability)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.updateAvailability"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/reports","path_regex":"^(?:/doubleclicksearch/v2/reports)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.request"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"POST","path_template":"/doubleclicksearch/v2/reports/generate","path_regex":"^(?:/doubleclicksearch/v2/reports/generate)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.reports.generate"},{"hostname":"doubleclicksearch.googleapis.com","http_method":"PUT","path_template":"/doubleclicksearch/v2/conversion","path_regex":"^(?:/doubleclicksearch/v2/conversion)$","service_name":"google.doubleclicksearch","resource_name":"doubleclicksearch.conversion.update"},{"hostname":"driveactivity.googleapis.com","http_method":"POST","path_template":"/v2/activity:query","path_regex":"^(?:/v2/activity:query)$","service_name":"google.driveactivity","resource_name":"driveactivity.activity.query"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2/labels/{labelsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2/labels/{labelsId}/permissions/{permissionsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions/{permissionsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2beta/labels/{labelsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2beta/labels/{labelsId}/permissions/{permissionsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"DELETE","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions/{permissionsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.delete"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels","path_regex":"^(?:/v2/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.get"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/locks","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/locks","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/limits/label","path_regex":"^(?:/v2/limits/label)$","service_name":"google.drivelabels","resource_name":"drivelabels.limits.getLabel"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2/users/{usersId}/capabilities","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capabilities)$","service_name":"google.drivelabels","resource_name":"drivelabels.users.getCapabilities"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels","path_regex":"^(?:/v2beta/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.get"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/locks","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/locks","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locks)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.locks.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.list"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/limits/label","path_regex":"^(?:/v2beta/limits/label)$","service_name":"google.drivelabels","resource_name":"drivelabels.limits.getLabel"},{"hostname":"drivelabels.googleapis.com","http_method":"GET","path_template":"/v2beta/users/{usersId}/capabilities","path_regex":"^(?:/v2beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capabilities)$","service_name":"google.drivelabels","resource_name":"drivelabels.users.getCapabilities"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2/labels/{labelsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2beta/labels/{labelsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"PATCH","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.updatePermissions"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels","path_regex":"^(?:/v2/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/permissions:batchDelete","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/permissions:batchUpdate","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions:batchDelete","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}/revisions/{revisionsId}/permissions:batchUpdate","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:delta","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delta)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delta"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:disable","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.disable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:enable","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.enable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:publish","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.publish"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2/labels/{labelsId}:updateLabelCopyMode","path_regex":"^(?:/v2/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateLabelCopyMode)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updateLabelCopyMode"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels","path_regex":"^(?:/v2beta/labels)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/permissions:batchDelete","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/permissions:batchUpdate","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.create"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions:batchDelete","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchDelete"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}/revisions/{revisionsId}/permissions:batchUpdate","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchUpdate)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.revisions.permissions.batchUpdate"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:delta","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::delta)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.delta"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:disable","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.disable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:enable","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.enable"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:publish","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.publish"},{"hostname":"drivelabels.googleapis.com","http_method":"POST","path_template":"/v2beta/labels/{labelsId}:updateLabelCopyMode","path_regex":"^(?:/v2beta/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateLabelCopyMode)$","service_name":"google.drivelabels","resource_name":"drivelabels.labels.updateLabelCopyMode"},{"hostname":"essentialcontacts.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/contacts/{contactsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.delete"},{"hostname":"essentialcontacts.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/contacts/{contactsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.delete"},{"hostname":"essentialcontacts.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/contacts/{contactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.delete"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/contacts","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.list"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/contacts/{contactsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.get"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/contacts:compute","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:compute)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.compute"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/contacts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.list"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/contacts/{contactsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.get"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/contacts:compute","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:compute)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.compute"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/contacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.list"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/contacts/{contactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.get"},{"hostname":"essentialcontacts.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/contacts:compute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:compute)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.compute"},{"hostname":"essentialcontacts.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/contacts/{contactsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.patch"},{"hostname":"essentialcontacts.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/contacts/{contactsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.patch"},{"hostname":"essentialcontacts.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/contacts/{contactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.patch"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/contacts","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.create"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/contacts:sendTestMessage","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:sendTestMessage)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.folders.contacts.sendTestMessage"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/contacts","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.create"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/contacts:sendTestMessage","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:sendTestMessage)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.organizations.contacts.sendTestMessage"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/contacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.create"},{"hostname":"essentialcontacts.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/contacts:sendTestMessage","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contacts:sendTestMessage)$","service_name":"google.essentialcontacts","resource_name":"essentialcontacts.projects.contacts.sendTestMessage"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.delete"},{"hostname":"eventarc.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.delete"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/googleChannelConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleChannelConfig)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.getGoogleChannelConfig"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.providers.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.providers.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.list"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.get"},{"hostname":"eventarc.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.getIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.patch"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/googleChannelConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/googleChannelConfig)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.updateGoogleChannelConfig"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.patch"},{"hostname":"eventarc.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.patch"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channelConnections/{channelConnectionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channelConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channelConnections.testIamPermissions"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/channels/{channelsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.channels.testIamPermissions"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.cancel"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.testIamPermissions"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.operations.cancel"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.create"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.setIamPolicy"},{"hostname":"eventarc.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/triggers/{triggersId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.eventarc","resource_name":"eventarc.projects.locations.triggers.testIamPermissions"},{"hostname":"factchecktools.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/pages/{pagesId}","path_regex":"^(?:/v1alpha1/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.delete"},{"hostname":"factchecktools.googleapis.com","http_method":"GET","path_template":"/v1alpha1/claims:imageSearch","path_regex":"^(?:/v1alpha1/claims:imageSearch)$","service_name":"google.factchecktools","resource_name":"factchecktools.claims.imageSearch"},{"hostname":"factchecktools.googleapis.com","http_method":"GET","path_template":"/v1alpha1/claims:search","path_regex":"^(?:/v1alpha1/claims:search)$","service_name":"google.factchecktools","resource_name":"factchecktools.claims.search"},{"hostname":"factchecktools.googleapis.com","http_method":"GET","path_template":"/v1alpha1/pages","path_regex":"^(?:/v1alpha1/pages)$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.list"},{"hostname":"factchecktools.googleapis.com","http_method":"GET","path_template":"/v1alpha1/pages/{pagesId}","path_regex":"^(?:/v1alpha1/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.get"},{"hostname":"factchecktools.googleapis.com","http_method":"POST","path_template":"/v1alpha1/pages","path_regex":"^(?:/v1alpha1/pages)$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.create"},{"hostname":"factchecktools.googleapis.com","http_method":"PUT","path_template":"/v1alpha1/pages/{pagesId}","path_regex":"^(?:/v1alpha1/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.factchecktools","resource_name":"factchecktools.pages.update"},{"hostname":"fcm.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/messages:send","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:send)$","service_name":"google.fcm","resource_name":"fcm.projects.messages.send"},{"hostname":"fcmdata.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/deliveryData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deliveryData)$","service_name":"google.fcmdata","resource_name":"fcmdata.projects.androidApps.deliveryData.list"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares/{sharesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.delete"},{"hostname":"file.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.delete"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.file","resource_name":"file.projects.locations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.file","resource_name":"file.projects.locations.operations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.file","resource_name":"file.projects.locations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares)$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares/{sharesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.get"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.file","resource_name":"file.projects.locations.operations.list"},{"hostname":"file.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.operations.get"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.backups.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares/{sharesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.patch"},{"hostname":"file.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.patch"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:promoteReplica","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promoteReplica)$","service_name":"google.file","resource_name":"file.projects.locations.instances.promoteReplica"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.file","resource_name":"file.projects.locations.instances.restore"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:revert","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.file","resource_name":"file.projects.locations.instances.revert"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.file","resource_name":"file.projects.locations.operations.cancel"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.file","resource_name":"file.projects.locations.backups.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.file","resource_name":"file.projects.locations.instances.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/shares","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shares)$","service_name":"google.file","resource_name":"file.projects.locations.instances.shares.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/snapshots","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.file","resource_name":"file.projects.locations.instances.snapshots.create"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:promoteReplica","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::promoteReplica)$","service_name":"google.file","resource_name":"file.projects.locations.instances.promoteReplica"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restore","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.file","resource_name":"file.projects.locations.instances.restore"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:revert","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.file","resource_name":"file.projects.locations.instances.revert"},{"hostname":"file.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.file","resource_name":"file.projects.locations.operations.cancel"},{"hostname":"firebase.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/sha/{shaId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sha/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.sha.delete"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/availableProjects","path_regex":"^(?:/v1beta1/availableProjects)$","service_name":"google.firebase","resource_name":"firebase.availableProjects.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.operations.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects","path_regex":"^(?:/v1beta1/projects)$","service_name":"google.firebase","resource_name":"firebase.projects.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/adminSdkConfig","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminSdkConfig)$","service_name":"google.firebase","resource_name":"firebase.projects.getAdminSdkConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/analyticsDetails","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyticsDetails)$","service_name":"google.firebase","resource_name":"firebase.projects.getAnalyticsDetails"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.getConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/sha","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sha)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.sha.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/availableLocations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/availableLocations)$","service_name":"google.firebase","resource_name":"firebase.projects.availableLocations.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/iosApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.getConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/webApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.list"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.get"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.getConfig"},{"hostname":"firebase.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}:searchApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchApps)$","service_name":"google.firebase","resource_name":"firebase.projects.searchApps"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.patch"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.patch"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.patch"},{"hostname":"firebase.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.patch"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}/sha","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sha)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.sha.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}:remove","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::remove)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.remove"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/androidApps/{androidAppsId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/androidApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebase","resource_name":"firebase.projects.androidApps.undelete"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/defaultLocation:finalize","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultLocation:finalize)$","service_name":"google.firebase","resource_name":"firebase.projects.defaultLocation.finalize"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/iosApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}:remove","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::remove)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.remove"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/iosApps/{iosAppsId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iosApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebase","resource_name":"firebase.projects.iosApps.undelete"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/webApps","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.create"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}:remove","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::remove)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.remove"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/webApps/{webAppsId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebase","resource_name":"firebase.projects.webApps.undelete"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:addFirebase","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFirebase)$","service_name":"google.firebase","resource_name":"firebase.projects.addFirebase"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:addGoogleAnalytics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addGoogleAnalytics)$","service_name":"google.firebase","resource_name":"firebase.projects.addGoogleAnalytics"},{"hostname":"firebase.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}:removeAnalytics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeAnalytics)$","service_name":"google.firebase","resource_name":"firebase.projects.removeAnalytics"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.delete"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/services/{servicesId}/resourcePolicies/{resourcePoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.delete"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.delete"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}/resourcePolicies/{resourcePoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.delete"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/jwks","path_regex":"^(?:/v1/jwks)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.jwks.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/appAttestConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/appAttestConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/deviceCheckConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/deviceCheckConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/playIntegrityConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/playIntegrityConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/recaptchaEnterpriseConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaEnterpriseConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/recaptchaV3Config:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaV3Config:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/-/safetyNetConfig:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/safetyNetConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services/{servicesId}/resourcePolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services/{servicesId}/resourcePolicies/{resourcePoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/jwks","path_regex":"^(?:/v1beta/jwks)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.jwks.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/appAttestConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/appAttestConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/deviceCheckConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/deviceCheckConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/playIntegrityConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/playIntegrityConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/recaptchaConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/recaptchaEnterpriseConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaEnterpriseConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/recaptchaV3Config:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/recaptchaV3Config:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/-/safetyNetConfig:batchGet","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/-/safetyNetConfig:batchGet)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.batchGet"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/services","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}/resourcePolicies","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.list"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}/resourcePolicies/{resourcePoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.get"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/services/{servicesId}/resourcePolicies/{resourcePoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/appAttestConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appAttestConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.appAttestConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens/{debugTokensId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/deviceCheckConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceCheckConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.deviceCheckConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/playIntegrityConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/playIntegrityConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.playIntegrityConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaEnterpriseConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaEnterpriseConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaEnterpriseConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/recaptchaV3Config","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recaptchaV3Config)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.recaptchaV3Config.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/safetyNetConfig","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/safetyNetConfig)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.safetyNetConfig.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}/resourcePolicies/{resourcePoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.patch"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/oauthClients/{oauthClientsId}:exchangeAppAttestAssertion","path_regex":"^(?:/v1/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAssertion)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.exchangeAppAttestAssertion"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/oauthClients/{oauthClientsId}:exchangeAppAttestAttestation","path_regex":"^(?:/v1/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAttestation)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.exchangeAppAttestAttestation"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/oauthClients/{oauthClientsId}:exchangeDebugToken","path_regex":"^(?:/v1/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDebugToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.exchangeDebugToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/oauthClients/{oauthClientsId}:generateAppAttestChallenge","path_regex":"^(?:/v1/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAppAttestChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.generateAppAttestChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.create"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAssertion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAssertion)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAssertion"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAttestation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAttestation)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAttestation"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeCustomToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeCustomToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeCustomToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeDebugToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDebugToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDebugToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeDeviceCheckToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDeviceCheckToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDeviceCheckToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangePlayIntegrityToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangePlayIntegrityToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangePlayIntegrityToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaEnterpriseToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaEnterpriseToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaEnterpriseToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaV3Token","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaV3Token)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaV3Token"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:exchangeSafetyNetToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeSafetyNetToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeSafetyNetToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:generateAppAttestChallenge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAppAttestChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generateAppAttestChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}:generatePlayIntegrityChallenge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generatePlayIntegrityChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generatePlayIntegrityChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services/{servicesId}/resourcePolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.create"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services/{servicesId}/resourcePolicies:batchUpdate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies:batchUpdate)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.batchUpdate"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services:batchUpdate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchUpdate)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.batchUpdate"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/oauthClients/{oauthClientsId}:exchangeAppAttestAssertion","path_regex":"^(?:/v1beta/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAssertion)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.exchangeAppAttestAssertion"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/oauthClients/{oauthClientsId}:exchangeAppAttestAttestation","path_regex":"^(?:/v1beta/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAttestation)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.exchangeAppAttestAttestation"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/oauthClients/{oauthClientsId}:exchangeDebugToken","path_regex":"^(?:/v1beta/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDebugToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.exchangeDebugToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/oauthClients/{oauthClientsId}:generateAppAttestChallenge","path_regex":"^(?:/v1beta/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAppAttestChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.oauthClients.generateAppAttestChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}/debugTokens","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/debugTokens)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.debugTokens.create"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAssertion","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAssertion)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAssertion"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeAppAttestAttestation","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeAppAttestAttestation)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeAppAttestAttestation"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeCustomToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeCustomToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeCustomToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeDebugToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDebugToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDebugToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeDeviceCheckToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeDeviceCheckToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeDeviceCheckToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangePlayIntegrityToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangePlayIntegrityToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangePlayIntegrityToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaEnterpriseToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaEnterpriseToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaEnterpriseToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeRecaptchaV3Token","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeRecaptchaV3Token)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeRecaptchaV3Token"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:exchangeSafetyNetToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exchangeSafetyNetToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.exchangeSafetyNetToken"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:generateAppAttestChallenge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAppAttestChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generateAppAttestChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/apps/{appsId}:generatePlayIntegrityChallenge","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generatePlayIntegrityChallenge)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.apps.generatePlayIntegrityChallenge"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}/resourcePolicies","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.create"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/services/{servicesId}/resourcePolicies:batchUpdate","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourcePolicies:batchUpdate)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.resourcePolicies.batchUpdate"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/services:batchUpdate","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchUpdate)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.services.batchUpdate"},{"hostname":"firebaseappcheck.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}:verifyAppCheckToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verifyAppCheckToken)$","service_name":"google.firebaseappcheck","resource_name":"firebaseappcheck.projects.verifyAppCheckToken"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/feedbackReports/{feedbackReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.feedbackReports.delete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.delete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.delete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/aabInfo","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/aabInfo)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.getAabInfo"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/feedbackReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackReports)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.feedbackReports.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/feedbackReports/{feedbackReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/feedbackReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.feedbackReports.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/testers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{mobilesdkAppId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{mobilesdkAppId}/jwt","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jwt)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.getJwt"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{mobilesdkAppId}/release_by_hash/{uploadHash}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/release_by_hash/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.release_by_hash.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{mobilesdkAppId}/testers:getTesterUdids","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers:getTesterUdids)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.testers.getTesterUdids"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/apps/{mobilesdkAppId}/upload_status/{uploadToken}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/upload_status/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.upload_status.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/tests","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tests)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.tests.list"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/tests/{testsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.tests.get"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/apps/{appsId}/testConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testConfig)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.getTestConfig"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/testers:udids","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers:udids)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.getUdids"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.patch"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.patch"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/testers/{testersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.patch"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/apps/{appsId}/testConfig","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testConfig)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.updateTestConfig"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.cancel"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.operations.wait"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases/{releasesId}:distribute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::distribute)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.distribute"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases:batchDelete)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.batchDelete"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/apps/{appsId}/releases:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases:upload)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.media.upload"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.create"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/groups/{groupsId}:batchJoin","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchJoin)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.batchJoin"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/groups/{groupsId}:batchLeave","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchLeave)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.groups.batchLeave"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/testers:batchAdd","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers:batchAdd)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.batchAdd"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/testers:batchRemove","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testers:batchRemove)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.testers.batchRemove"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1alpha/apps/{mobilesdkAppId}","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.provisionApp"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1alpha/apps/{mobilesdkAppId}/releases/{releaseId}/enable_access","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/enable_access)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.releases.enable_access"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1alpha/apps/{mobilesdkAppId}/releases/{releaseId}/notes","path_regex":"^(?:/v1alpha/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.apps.releases.notes.create"},{"hostname":"firebaseappdistribution.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/apps/{appsId}/releases/{releasesId}/tests","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tests)$","service_name":"google.firebaseappdistribution","resource_name":"firebaseappdistribution.projects.apps.releases.tests.create"},{"hostname":"firebasedatabase.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.delete"},{"hostname":"firebasedatabase.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.list"},{"hostname":"firebasedatabase.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.get"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.create"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:disable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.disable"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reenable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reenable)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.reenable"},{"hostname":"firebasedatabase.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:undelete","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebasedatabase","resource_name":"firebasedatabase.projects.locations.instances.undelete"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"GET","path_template":"/v1/{dynamicLink}/linkStats","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/linkStats)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.getLinkStats"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/installAttribution","path_regex":"^(?:/v1/installAttribution)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.installAttribution"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/managedShortLinks:create","path_regex":"^(?:/v1/managedShortLinks:create)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.managedShortLinks.create"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/reopenAttribution","path_regex":"^(?:/v1/reopenAttribution)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.reopenAttribution"},{"hostname":"firebasedynamiclinks.googleapis.com","http_method":"POST","path_template":"/v1/shortLinks","path_regex":"^(?:/v1/shortLinks)$","service_name":"google.firebasedynamiclinks","resource_name":"firebasedynamiclinks.shortLinks.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.operations.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.operations.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.delete"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.operations.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.operations.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.getConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.operations.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.operations.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}/files","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.files.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.getConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.releases.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/releases/{releasesId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.releases.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.get"},{"hostname":"firebasehosting.googleapis.com","http_method":"GET","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}/files","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.files.list"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.updateConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/sites/{sitesId}/config","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.updateConfig"},{"hostname":"firebasehosting.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.patch"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.operations.cancel"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.operations.cancel"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.channels.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/customDomains/{customDomainsId}:undelete","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.customDomains.undelete"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions/{versionsId}:populateFiles","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::populateFiles)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.populateFiles"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/versions:clone","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:clone)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.versions.clone"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/channels","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/channels/{channelsId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.channels.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/domains","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/releases","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.releases.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/versions","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.create"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/versions/{versionsId}:populateFiles","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::populateFiles)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.populateFiles"},{"hostname":"firebasehosting.googleapis.com","http_method":"POST","path_template":"/v1beta1/sites/{sitesId}/versions:clone","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:clone)$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.versions.clone"},{"hostname":"firebasehosting.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.projects.sites.domains.update"},{"hostname":"firebasehosting.googleapis.com","http_method":"PUT","path_template":"/v1beta1/sites/{sitesId}/domains/{domainsId}","path_regex":"^(?:/v1beta1/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasehosting","resource_name":"firebasehosting.sites.domains.update"},{"hostname":"firebaseml.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.operations.delete"},{"hostname":"firebaseml.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.delete"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.firebaseml","resource_name":"firebaseml.operations.list"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/models","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.list"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.get"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}:download","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.download"},{"hostname":"firebaseml.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.operations.get"},{"hostname":"firebaseml.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.patch"},{"hostname":"firebaseml.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firebaseml","resource_name":"firebaseml.operations.cancel"},{"hostname":"firebaseml.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/models","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.models.create"},{"hostname":"firebaseml.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:countTokens","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::countTokens)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.locations.publishers.models.countTokens"},{"hostname":"firebaseml.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:generateContent","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateContent)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.locations.publishers.models.generateContent"},{"hostname":"firebaseml.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/publishers/{publishersId}/models/{modelsId}:streamGenerateContent","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publishers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamGenerateContent)$","service_name":"google.firebaseml","resource_name":"firebaseml.projects.locations.publishers.models.streamGenerateContent"},{"hostname":"firebaseremoteconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/remoteConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remoteConfig)$","service_name":"google.firebaseremoteconfig","resource_name":"firebaseremoteconfig.projects.getRemoteConfig"},{"hostname":"firebaseremoteconfig.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/remoteConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remoteConfig)$","service_name":"google.firebaseremoteconfig","resource_name":"firebaseremoteconfig.projects.updateRemoteConfig"},{"hostname":"firebaserules.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.delete"},{"hostname":"firebaserules.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/rulesets/{rulesetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.delete"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.list"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.get"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/releases/{releasesId}:getExecutable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getExecutable)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.getExecutable"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/rulesets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.list"},{"hostname":"firebaserules.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/rulesets/{rulesetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.get"},{"hostname":"firebaserules.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/releases/{releasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.patch"},{"hostname":"firebaserules.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/releases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.releases.create"},{"hostname":"firebaserules.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/rulesets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rulesets)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.rulesets.create"},{"hostname":"firebaserules.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:test","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::test)$","service_name":"google.firebaserules","resource_name":"firebaserules.projects.test"},{"hostname":"firebasestorage.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/buckets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.list"},{"hostname":"firebasestorage.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/buckets/{bucketsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.get"},{"hostname":"firebasestorage.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/buckets/{bucketsId}:addFirebase","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFirebase)$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.addFirebase"},{"hostname":"firebasestorage.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/buckets/{bucketsId}:removeFirebase","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFirebase)$","service_name":"google.firebasestorage","resource_name":"firebasestorage.projects.buckets.removeFirebase"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.backupSchedules.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.locations.backups.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes/{indexesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.delete"},{"hostname":"firestore.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.delete"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/backupSchedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.backupSchedules.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.backupSchedules.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{collectionId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listDocuments"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}/{collectionId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.firestore","resource_name":"firestore.projects.locations.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.locations.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.firestore","resource_name":"firestore.projects.locations.backups.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.locations.backups.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{collectionId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listDocuments"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}/{collectionId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes/{indexesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.get"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.list"},{"hostname":"firestore.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes/{indexesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.get"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.backupSchedules.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.patch"},{"hostname":"firestore.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/fields/{fieldsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.fields.patch"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/backupSchedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.backupSchedules.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{collectionId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.createDocument"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:listCollectionIds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listCollectionIds)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listCollectionIds"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:partitionQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.partitionQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runAggregationQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runAggregationQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchGet)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchGet"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:batchWrite","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchWrite)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchWrite"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:beginTransaction","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:beginTransaction)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.beginTransaction"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:commit)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.commit"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:listen","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:listen)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listen"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:rollback)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.rollback"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/documents:write","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:write)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.write"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.operations.cancel"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}:bulkDeleteDocuments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::bulkDeleteDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.bulkDeleteDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}:exportDocuments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.exportDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases/{databasesId}:importDocuments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.importDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/databases:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases:restore)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.restore"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{collectionId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.createDocument"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:listCollectionIds","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listCollectionIds)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listCollectionIds"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:partitionQuery","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.partitionQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runAggregationQuery","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runAggregationQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runAggregationQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents/{documentsId}/{documentsId1}:runQuery","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::runQuery)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.runQuery"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:batchGet","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchGet)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchGet"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:batchWrite","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:batchWrite)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.batchWrite"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:beginTransaction","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:beginTransaction)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.beginTransaction"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:commit","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:commit)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.commit"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:listen","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:listen)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.listen"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:rollback)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.rollback"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/documents:write","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/documents:write)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.documents.write"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}/indexes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.indexes.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}:exportDocuments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.exportDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/databases/{databasesId}:importDocuments","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.importDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}/collectionGroups/{collectionGroupsId}/indexes","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.collectionGroups.indexes.create"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}:exportDocuments","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.exportDocuments"},{"hostname":"firestore.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/databases/{databasesId}:importDocuments","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importDocuments)$","service_name":"google.firestore","resource_name":"firestore.projects.databases.importDocuments"},{"hostname":"fitness.googleapis.com","http_method":"DELETE","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.delete"},{"hostname":"fitness.googleapis.com","http_method":"DELETE","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/datasets/{datasetId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.datasets.delete"},{"hostname":"fitness.googleapis.com","http_method":"DELETE","path_template":"/fitness/v1/users/{userId}/sessions/{sessionId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.sessions.delete"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.list"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.get"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/dataPointChanges","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataPointChanges)$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.dataPointChanges.list"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/datasets/{datasetId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.datasets.get"},{"hostname":"fitness.googleapis.com","http_method":"GET","path_template":"/fitness/v1/users/{userId}/sessions","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.fitness","resource_name":"fitness.users.sessions.list"},{"hostname":"fitness.googleapis.com","http_method":"PATCH","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}/datasets/{datasetId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.datasets.patch"},{"hostname":"fitness.googleapis.com","http_method":"POST","path_template":"/fitness/v1/users/{userId}/dataSources","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.create"},{"hostname":"fitness.googleapis.com","http_method":"POST","path_template":"/fitness/v1/users/{userId}/dataset:aggregate","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataset:aggregate)$","service_name":"google.fitness","resource_name":"fitness.users.dataset.aggregate"},{"hostname":"fitness.googleapis.com","http_method":"PUT","path_template":"/fitness/v1/users/{userId}/dataSources/{dataSourceId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.dataSources.update"},{"hostname":"fitness.googleapis.com","http_method":"PUT","path_template":"/fitness/v1/users/{userId}/sessions/{sessionId}","path_regex":"^(?:/fitness/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fitness","resource_name":"fitness.users.sessions.update"},{"hostname":"forms.googleapis.com","http_method":"DELETE","path_template":"/v1/forms/{formId}/watches/{watchId}","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.forms","resource_name":"forms.forms.watches.delete"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.forms","resource_name":"forms.forms.get"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}/responses","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responses)$","service_name":"google.forms","resource_name":"forms.forms.responses.list"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}/responses/{responseId}","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/responses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.forms","resource_name":"forms.forms.responses.get"},{"hostname":"forms.googleapis.com","http_method":"GET","path_template":"/v1/forms/{formId}/watches","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches)$","service_name":"google.forms","resource_name":"forms.forms.watches.list"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms","path_regex":"^(?:/v1/forms)$","service_name":"google.forms","resource_name":"forms.forms.create"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms/{formId}/watches","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches)$","service_name":"google.forms","resource_name":"forms.forms.watches.create"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms/{formId}/watches/{watchId}:renew","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::renew)$","service_name":"google.forms","resource_name":"forms.forms.watches.renew"},{"hostname":"forms.googleapis.com","http_method":"POST","path_template":"/v1/forms/{formId}:batchUpdate","path_regex":"^(?:/v1/forms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.forms","resource_name":"forms.forms.batchUpdate"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/achievements","path_regex":"^(?:/games/v1/achievements)$","service_name":"google.games","resource_name":"games.achievementDefinitions.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/applications/{applicationId}","path_regex":"^(?:/games/v1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.applications.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/applications/{applicationId}/verify","path_regex":"^(?:/games/v1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verify)$","service_name":"google.games","resource_name":"games.applications.verify"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/eventDefinitions","path_regex":"^(?:/games/v1/eventDefinitions)$","service_name":"google.games","resource_name":"games.events.listDefinitions"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/events","path_regex":"^(?:/games/v1/events)$","service_name":"google.games","resource_name":"games.events.listByPlayer"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards","path_regex":"^(?:/games/v1/leaderboards)$","service_name":"google.games","resource_name":"games.leaderboards.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.leaderboards.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards/{leaderboardId}/scores/{collection}","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.scores.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/leaderboards/{leaderboardId}/window/{collection}","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/window/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.scores.listWindow"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/metagameConfig","path_regex":"^(?:/games/v1/metagameConfig)$","service_name":"google.games","resource_name":"games.metagame.getMetagameConfig"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/me/multipleApplicationPlayerIds","path_regex":"^(?:/games/v1/players/me/multipleApplicationPlayerIds)$","service_name":"google.games","resource_name":"games.players.getMultipleApplicationPlayerIds"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/me/players/{collection}","path_regex":"^(?:/games/v1/players/me/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.players.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/me/scopedIds","path_regex":"^(?:/games/v1/players/me/scopedIds)$","service_name":"google.games","resource_name":"games.players.getScopedPlayerIds"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.players.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/achievements","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/achievements)$","service_name":"google.games","resource_name":"games.achievements.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/categories/{collection}","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/categories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.metagame.listCategoriesByPlayer"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/leaderboards/{leaderboardId}/scores/{timeSpan}","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.scores.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/players/{playerId}/snapshots","path_regex":"^(?:/games/v1/players/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.games","resource_name":"games.snapshots.list"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/recall/developerGamesLastPlayerToken/{sessionId}","path_regex":"^(?:/games/v1/recall/developerGamesLastPlayerToken/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.recall.lastTokenFromAllDeveloperGames"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/recall/gamesPlayerTokens/{sessionId}","path_regex":"^(?:/games/v1/recall/gamesPlayerTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.recall.gamesPlayerTokens"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/recall/tokens/{sessionId}","path_regex":"^(?:/games/v1/recall/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.recall.retrieveTokens"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/revisions/check","path_regex":"^(?:/games/v1/revisions/check)$","service_name":"google.games","resource_name":"games.revisions.check"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/snapshots/{snapshotId}","path_regex":"^(?:/games/v1/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.games","resource_name":"games.snapshots.get"},{"hostname":"games.googleapis.com","http_method":"GET","path_template":"/games/v1/stats","path_regex":"^(?:/games/v1/stats)$","service_name":"google.games","resource_name":"games.stats.get"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/accesstokens/generatePlayGroupingApiToken","path_regex":"^(?:/games/v1/accesstokens/generatePlayGroupingApiToken)$","service_name":"google.games","resource_name":"games.accesstokens.generatePlayGroupingApiToken"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/accesstokens/generateRecallPlayGroupingApiToken","path_regex":"^(?:/games/v1/accesstokens/generateRecallPlayGroupingApiToken)$","service_name":"google.games","resource_name":"games.accesstokens.generateRecallPlayGroupingApiToken"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/updateMultiple","path_regex":"^(?:/games/v1/achievements/updateMultiple)$","service_name":"google.games","resource_name":"games.achievements.updateMultiple"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/increment","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/increment)$","service_name":"google.games","resource_name":"games.achievements.increment"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/reveal","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reveal)$","service_name":"google.games","resource_name":"games.achievements.reveal"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/setStepsAtLeast","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setStepsAtLeast)$","service_name":"google.games","resource_name":"games.achievements.setStepsAtLeast"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/achievements/{achievementId}/unlock","path_regex":"^(?:/games/v1/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unlock)$","service_name":"google.games","resource_name":"games.achievements.unlock"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/applications/getEndPoint","path_regex":"^(?:/games/v1/applications/getEndPoint)$","service_name":"google.games","resource_name":"games.applications.getEndPoint"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/applications/played","path_regex":"^(?:/games/v1/applications/played)$","service_name":"google.games","resource_name":"games.applications.played"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/events","path_regex":"^(?:/games/v1/events)$","service_name":"google.games","resource_name":"games.events.record"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/leaderboards/scores","path_regex":"^(?:/games/v1/leaderboards/scores)$","service_name":"google.games","resource_name":"games.scores.submitMultiple"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/leaderboards/{leaderboardId}/scores","path_regex":"^(?:/games/v1/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores)$","service_name":"google.games","resource_name":"games.scores.submit"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/recall:linkPersona","path_regex":"^(?:/games/v1/recall:linkPersona)$","service_name":"google.games","resource_name":"games.recall.linkPersona"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/recall:resetPersona","path_regex":"^(?:/games/v1/recall:resetPersona)$","service_name":"google.games","resource_name":"games.recall.resetPersona"},{"hostname":"games.googleapis.com","http_method":"POST","path_template":"/games/v1/recall:unlinkPersona","path_regex":"^(?:/games/v1/recall:unlinkPersona)$","service_name":"google.games","resource_name":"games.recall.unlinkPersona"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"DELETE","path_template":"/games/v1configuration/achievements/{achievementId}","path_regex":"^(?:/games/v1configuration/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.delete"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"DELETE","path_template":"/games/v1configuration/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1configuration/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.delete"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/achievements/{achievementId}","path_regex":"^(?:/games/v1configuration/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.get"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/applications/{applicationId}/achievements","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/achievements)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.list"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/applications/{applicationId}/leaderboards","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leaderboards)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.list"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"GET","path_template":"/games/v1configuration/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1configuration/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.get"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"POST","path_template":"/games/v1configuration/applications/{applicationId}/achievements","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/achievements)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.insert"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"POST","path_template":"/games/v1configuration/applications/{applicationId}/leaderboards","path_regex":"^(?:/games/v1configuration/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leaderboards)$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.insert"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"PUT","path_template":"/games/v1configuration/achievements/{achievementId}","path_regex":"^(?:/games/v1configuration/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.achievementConfigurations.update"},{"hostname":"gamesconfiguration.googleapis.com","http_method":"PUT","path_template":"/games/v1configuration/leaderboards/{leaderboardId}","path_regex":"^(?:/games/v1configuration/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesConfiguration","resource_name":"gamesConfiguration.leaderboardConfigurations.update"},{"hostname":"gameservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.delete"},{"hostname":"gameservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.delete"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.get"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.getIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.get"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.get"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.getIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.list"},{"hostname":"gameservices.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.get"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.setIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.testIamPermissions"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.cancel"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.setIamPolicy"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/gameServerDeployments/{gameServerDeploymentsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gameServerDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.gameServerDeployments.testIamPermissions"},{"hostname":"gameservices.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gameservices","resource_name":"gameservices.projects.locations.operations.cancel"},{"hostname":"gamesmanagement.googleapis.com","http_method":"DELETE","path_template":"/games/v1management/applications/{applicationId}/players/hidden/{playerId}","path_regex":"^(?:/games/v1management/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/players/hidden/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesManagement","resource_name":"gamesManagement.players.unhide"},{"hostname":"gamesmanagement.googleapis.com","http_method":"GET","path_template":"/games/v1management/applications/{applicationId}/players/hidden","path_regex":"^(?:/games/v1management/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/players/hidden)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.applications.listHidden"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/reset","path_regex":"^(?:/games/v1management/achievements/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetAll"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/resetAllForAllPlayers","path_regex":"^(?:/games/v1management/achievements/resetAllForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetAllForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/resetMultipleForAllPlayers","path_regex":"^(?:/games/v1management/achievements/resetMultipleForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetMultipleForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/{achievementId}/reset","path_regex":"^(?:/games/v1management/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.reset"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/achievements/{achievementId}/resetForAllPlayers","path_regex":"^(?:/games/v1management/achievements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.achievements.resetForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/applications/{applicationId}/players/hidden/{playerId}","path_regex":"^(?:/games/v1management/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/players/hidden/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gamesManagement","resource_name":"gamesManagement.players.hide"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/reset","path_regex":"^(?:/games/v1management/events/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetAll"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/resetAllForAllPlayers","path_regex":"^(?:/games/v1management/events/resetAllForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetAllForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/resetMultipleForAllPlayers","path_regex":"^(?:/games/v1management/events/resetMultipleForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetMultipleForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/{eventId}/reset","path_regex":"^(?:/games/v1management/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.reset"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/events/{eventId}/resetForAllPlayers","path_regex":"^(?:/games/v1management/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.events.resetForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/leaderboards/{leaderboardId}/scores/reset","path_regex":"^(?:/games/v1management/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.reset"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/leaderboards/{leaderboardId}/scores/resetForAllPlayers","path_regex":"^(?:/games/v1management/leaderboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scores/resetForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/scores/reset","path_regex":"^(?:/games/v1management/scores/reset)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetAll"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/scores/resetAllForAllPlayers","path_regex":"^(?:/games/v1management/scores/resetAllForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetAllForAllPlayers"},{"hostname":"gamesmanagement.googleapis.com","http_method":"POST","path_template":"/games/v1management/scores/resetMultipleForAllPlayers","path_regex":"^(?:/games/v1management/scores/resetMultipleForAllPlayers)$","service_name":"google.gamesManagement","resource_name":"gamesManagement.scores.resetMultipleForAllPlayers"},{"hostname":"genomics.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/pipelines/{pipelineId}","path_regex":"^(?:/v1alpha2/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.pipelines.delete"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/operations","path_regex":"^(?:/v1alpha2/operations)$","service_name":"google.genomics","resource_name":"genomics.operations.list"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/operations/{operationsId}","path_regex":"^(?:/v1alpha2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.operations.get"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/pipelines","path_regex":"^(?:/v1alpha2/pipelines)$","service_name":"google.genomics","resource_name":"genomics.pipelines.list"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/pipelines/{pipelineId}","path_regex":"^(?:/v1alpha2/pipelines/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.pipelines.get"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v1alpha2/pipelines:getControllerConfig","path_regex":"^(?:/v1alpha2/pipelines:getControllerConfig)$","service_name":"google.genomics","resource_name":"genomics.pipelines.getControllerConfig"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/operations","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.genomics","resource_name":"genomics.projects.operations.list"},{"hostname":"genomics.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.genomics","resource_name":"genomics.projects.operations.get"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v1alpha2/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.genomics","resource_name":"genomics.operations.cancel"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v1alpha2/pipelines","path_regex":"^(?:/v1alpha2/pipelines)$","service_name":"google.genomics","resource_name":"genomics.pipelines.create"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v1alpha2/pipelines:run","path_regex":"^(?:/v1alpha2/pipelines:run)$","service_name":"google.genomics","resource_name":"genomics.pipelines.run"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/pipelines:run","path_regex":"^(?:/v2alpha1/pipelines:run)$","service_name":"google.genomics","resource_name":"genomics.pipelines.run"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.genomics","resource_name":"genomics.projects.operations.cancel"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/workers/{workersId}:checkIn","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkIn)$","service_name":"google.genomics","resource_name":"genomics.projects.workers.checkIn"},{"hostname":"genomics.googleapis.com","http_method":"POST","path_template":"/v2alpha1/workers/{id}:checkIn","path_regex":"^(?:/v2alpha1/workers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkIn)$","service_name":"google.genomics","resource_name":"genomics.workers.checkIn"},{"hostname":"genomics.googleapis.com","http_method":"PUT","path_template":"/v1alpha2/pipelines:setOperationStatus","path_regex":"^(?:/v1alpha2/pipelines:setOperationStatus)$","service_name":"google.genomics","resource_name":"genomics.pipelines.setOperationStatus"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.operations.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.delete"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}:getBackupIndexDownloadUrl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getBackupIndexDownloadUrl)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.getBackupIndexDownloadUrl"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.operations.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.operations.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.list"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.get"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.getIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.patch"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}/volumeBackups/{volumeBackupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeBackups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.volumeBackups.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.backups.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/backupPlans/{backupPlansId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupPlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.backupPlans.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.operations.cancel"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.create"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}/volumeRestores/{volumeRestoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/volumeRestores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.volumeRestores.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}/restores/{restoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.restores.testIamPermissions"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.setIamPolicy"},{"hostname":"gkebackup.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/restorePlans/{restorePlansId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restorePlans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkebackup","resource_name":"gkebackup.projects.locations.restorePlans.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.delete"},{"hostname":"gkehub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.delete"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.organizations.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:listMemberships","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listMemberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.listMemberships"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes:listPermitted","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes:listPermitted)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.listPermitted"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.organizations.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships:listAdmin","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:listAdmin)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.listAdmin"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:listMemberships","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listMemberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.listMemberships"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes:listPermitted","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes:listPermitted)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.listPermitted"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.organizations.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:listMemberships","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listMemberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.listMemberships"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes:listPermitted","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes:listPermitted)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.listPermitted"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateConnectManifest","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateConnectManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateConnectManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:generateExclusivityManifest","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateExclusivityManifest)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.generateExclusivityManifest"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.getIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships:validateExclusivity","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:validateExclusivity)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.validateExclusivity"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.get"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.list"},{"hostname":"gkehub.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.get"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets/{fleetsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings/{bindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings/{rbacrolebindingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.patch"},{"hostname":"gkehub.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.patch"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings:generateMembershipRBACRoleBindingYAML","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings:generateMembershipRBACRoleBindingYAML)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.generateMembershipRBACRoleBindingYAML"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings:generateMembershipRBACRoleBindingYAML","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings:generateMembershipRBACRoleBindingYAML)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.generateMembershipRBACRoleBindingYAML"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/memberships:validateCreate","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships:validateCreate)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.validateCreate"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/global/memberships:initializeHub","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/memberships:initializeHub)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.global.memberships.initializeHub"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/features/{featuresId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/features/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.features.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/fleets","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fleets)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.fleets.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/bindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.bindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}/rbacrolebindings:generateMembershipRBACRoleBindingYAML","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings:generateMembershipRBACRoleBindingYAML)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.rbacrolebindings.generateMembershipRBACRoleBindingYAML"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/namespaces","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.namespaces.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}/rbacrolebindings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rbacrolebindings)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.rbacrolebindings.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/scopes/{scopesId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.scopes.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.create"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.setIamPolicy"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/memberships/{membershipsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.memberships.testIamPermissions"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkehub.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkehub","resource_name":"gkehub.projects.locations.operations.cancel"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}:unenroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unenroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.unenroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.delete"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.delete"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}:unenroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unenroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.unenroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}:unenroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unenroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.unenroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.operations.delete"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}:unenroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unenroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.unenroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.delete"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.delete"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}:unenroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unenroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.unenroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}:unenroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unenroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.unenroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.operations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.operations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.getIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.operations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.operations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.getIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.operations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.operations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.getIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.operations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.operations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.operations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.operations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.getIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.operations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.operations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.operations.list"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.operations.get"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.getIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.getIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.patch"},{"hostname":"gkeonprem.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.patch"},{"hostname":"gkeonprem.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.patch"},{"hostname":"gkeonprem.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.patch"},{"hostname":"gkeonprem.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.patch"},{"hostname":"gkeonprem.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.patch"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.create"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.setIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters/{bareMetalAdminClustersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.testIamPermissions"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters:enroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters:enroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.enroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalAdminClusters:queryVersionConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalAdminClusters:queryVersionConfig)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalAdminClusters.queryVersionConfig"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.create"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.create"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.setIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools/{bareMetalNodePoolsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.testIamPermissions"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}/bareMetalNodePools:enroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalNodePools:enroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.bareMetalNodePools.enroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.setIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters/{bareMetalClustersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.testIamPermissions"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters:enroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters:enroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.enroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/bareMetalClusters:queryVersionConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bareMetalClusters:queryVersionConfig)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.bareMetalClusters.queryVersionConfig"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.operations.cancel"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.setIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters/{vmwareAdminClustersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.testIamPermissions"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareAdminClusters:enroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareAdminClusters:enroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareAdminClusters.enroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.create"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.create"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.setIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools/{vmwareNodePoolsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.testIamPermissions"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}/vmwareNodePools:enroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareNodePools:enroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.vmwareNodePools.enroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.setIamPolicy"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters/{vmwareClustersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.testIamPermissions"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters:enroll","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters:enroll)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.enroll"},{"hostname":"gkeonprem.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareClusters:queryVersionConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareClusters:queryVersionConfig)$","service_name":"google.gkeonprem","resource_name":"gkeonprem.projects.locations.vmwareClusters.queryVersionConfig"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/drafts/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.drafts.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/messages/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.messages.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/cse/identities/{cseEmailAddress}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/delegates/{delegateEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/filters/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses/{forwardingEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.delete"},{"hostname":"gmail.googleapis.com","http_method":"DELETE","path_template":"/gmail/v1/users/{userId}/threads/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.threads.delete"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/drafts","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts)$","service_name":"google.gmail","resource_name":"gmail.users.drafts.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/drafts/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.drafts.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/history","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/history)$","service_name":"google.gmail","resource_name":"gmail.users.history.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/labels","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.gmail","resource_name":"gmail.users.labels.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/messages","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.gmail","resource_name":"gmail.users.messages.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/messages/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.messages.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/messages/{messageId}/attachments/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.messages.attachments.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/profile","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profile)$","service_name":"google.gmail","resource_name":"gmail.users.getProfile"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/autoForwarding","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/autoForwarding)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getAutoForwarding"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/identities","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/identities/{cseEmailAddress}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/delegates","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates)$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/delegates/{delegateEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/filters","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters)$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/filters/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses)$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses/{forwardingEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/imap","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/imap)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getImap"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/language","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/language)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getLanguage"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/pop","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/pop)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getPop"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.get"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/settings/vacation","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/vacation)$","service_name":"google.gmail","resource_name":"gmail.users.settings.getVacation"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/threads","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads)$","service_name":"google.gmail","resource_name":"gmail.users.threads.list"},{"hostname":"gmail.googleapis.com","http_method":"GET","path_template":"/gmail/v1/users/{userId}/threads/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.threads.get"},{"hostname":"gmail.googleapis.com","http_method":"PATCH","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.patch"},{"hostname":"gmail.googleapis.com","http_method":"PATCH","path_template":"/gmail/v1/users/{userId}/settings/cse/identities/{emailAddress}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.patch"},{"hostname":"gmail.googleapis.com","http_method":"PATCH","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.patch"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/drafts","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts)$","service_name":"google.gmail","resource_name":"gmail.users.drafts.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/drafts/send","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/send)$","service_name":"google.gmail","resource_name":"gmail.users.drafts.send"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/labels","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.gmail","resource_name":"gmail.users.labels.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.gmail","resource_name":"gmail.users.messages.insert"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/batchDelete","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/batchDelete)$","service_name":"google.gmail","resource_name":"gmail.users.messages.batchDelete"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/batchModify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/batchModify)$","service_name":"google.gmail","resource_name":"gmail.users.messages.batchModify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/import","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/import)$","service_name":"google.gmail","resource_name":"gmail.users.messages.import"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/send","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/send)$","service_name":"google.gmail","resource_name":"gmail.users.messages.send"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/{id}/modify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modify)$","service_name":"google.gmail","resource_name":"gmail.users.messages.modify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/{id}/trash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trash)$","service_name":"google.gmail","resource_name":"gmail.users.messages.trash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/messages/{id}/untrash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/untrash)$","service_name":"google.gmail","resource_name":"gmail.users.messages.untrash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/identities","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/identities)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.identities.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}:disable","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.disable"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}:enable","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.enable"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/cse/keypairs/{keyPairId}:obliterate","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/cse/keypairs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::obliterate)$","service_name":"google.gmail","resource_name":"gmail.users.settings.cse.keypairs.obliterate"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/delegates","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/delegates)$","service_name":"google.gmail","resource_name":"gmail.users.settings.delegates.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/filters","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/filters)$","service_name":"google.gmail","resource_name":"gmail.users.settings.filters.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/forwardingAddresses","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/forwardingAddresses)$","service_name":"google.gmail","resource_name":"gmail.users.settings.forwardingAddresses.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.create"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.insert"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/smimeInfo/{id}/setDefault","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/smimeInfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setDefault)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.smimeInfo.setDefault"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}/verify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verify)$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.verify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/stop","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.gmail","resource_name":"gmail.users.stop"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/threads/{id}/modify","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modify)$","service_name":"google.gmail","resource_name":"gmail.users.threads.modify"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/threads/{id}/trash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trash)$","service_name":"google.gmail","resource_name":"gmail.users.threads.trash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/threads/{id}/untrash","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/threads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/untrash)$","service_name":"google.gmail","resource_name":"gmail.users.threads.untrash"},{"hostname":"gmail.googleapis.com","http_method":"POST","path_template":"/gmail/v1/users/{userId}/watch","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.gmail","resource_name":"gmail.users.watch"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/drafts/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/drafts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.drafts.update"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/labels/{id}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.labels.update"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/autoForwarding","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/autoForwarding)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateAutoForwarding"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/imap","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/imap)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateImap"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/language","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/language)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateLanguage"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/pop","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/pop)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updatePop"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/sendAs/{sendAsEmail}","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/sendAs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmail","resource_name":"gmail.users.settings.sendAs.update"},{"hostname":"gmail.googleapis.com","http_method":"PUT","path_template":"/gmail/v1/users/{userId}/settings/vacation","path_regex":"^(?:/gmail/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/vacation)$","service_name":"google.gmail","resource_name":"gmail.users.settings.updateVacation"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains","path_regex":"^(?:/v1/domains)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains/{domainsId}","path_regex":"^(?:/v1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.get"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains/{domainsId}/trafficStats","path_regex":"^(?:/v1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1/domains/{domainsId}/trafficStats/{trafficStatsId}","path_regex":"^(?:/v1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.get"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains","path_regex":"^(?:/v1beta1/domains)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains/{domainsId}","path_regex":"^(?:/v1beta1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.get"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains/{domainsId}/trafficStats","path_regex":"^(?:/v1beta1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats)$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.list"},{"hostname":"gmailpostmastertools.googleapis.com","http_method":"GET","path_template":"/v1beta1/domains/{domainsId}/trafficStats/{trafficStatsId}","path_regex":"^(?:/v1beta1/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trafficStats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.gmailpostmastertools","resource_name":"gmailpostmastertools.domains.trafficStats.get"},{"hostname":"groupsmigration.googleapis.com","http_method":"POST","path_template":"/groups/v1/groups/{groupId}/archive","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/archive)$","service_name":"google.groupsmigration","resource_name":"groupsmigration.archive.insert"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.deleteRevision"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalDelete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/$purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$purge)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-purge"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalDelete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/$purge","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$purge)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-purge"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:deleteRevision","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.deleteRevision"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalDelete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/$purge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$purge)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-purge"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.delete"},{"hostname":"healthcare.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.delete"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.listRevisions"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataMapperWorkspaces/{dataMapperWorkspacesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataMapperWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dataMapperWorkspaces.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/series","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForStudies"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveStudy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveInstance"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveFrames"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}/rendered","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/rendered","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}:getSeriesMetrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getSeriesMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.getSeriesMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}:getStudyMetrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getStudyMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.getStudyMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getDICOMStoreMetrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDICOMStoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getDICOMStoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Patient/{PatientId}/$everything","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Patient/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$everything)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Patient-everything"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.history"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history/{_historyId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.vread"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getFHIRStoreMetrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getFHIRStoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getFHIRStoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getHL7v2StoreMetrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getHL7v2StoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getHL7v2StoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/instances","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/series","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.searchForStudies"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.retrieveStudy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/instances","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.metadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.retrieveSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.retrieveInstance"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.frames.retrieveFrames"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}/rendered","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.frames.rendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.metadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/rendered","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.rendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.metadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Observation/$lastn","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Observation/\\$lastn)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Observation-lastn"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Patient/{PatientId}/$everything","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Patient/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$everything)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Patient-everything"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.history"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history/{_historyId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.vread"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/metadata","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts/{consentArtifactsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:listRevisions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.listRevisions"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataMapperWorkspaces/{dataMapperWorkspacesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataMapperWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dataMapperWorkspaces.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/series","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.searchForStudies"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveStudy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.searchForSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveSeries"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.searchForInstances"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveInstance"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/bulkdata/{bulkdataId}/{bulkdataId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bulkdata/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.bulkdata.retrieveBulkdata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveFrames"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/frames/{framesId}/rendered","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/frames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.frames.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}/rendered","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rendered)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.instances.retrieveRendered"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/instances/{instancesId}:getStorageInfo","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getStorageInfo)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.instances.getStorageInfo"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.series.retrieveMetadata"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}/series/{seriesId}:getSeriesMetrics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/series/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getSeriesMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.series.getSeriesMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}:getStudyMetrics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getStudyMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.getStudyMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getDICOMStoreMetrics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDICOMStoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getDICOMStoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/$references","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/\\$references)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-incoming-references"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/ConceptMap/$translate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/ConceptMap/\\$translate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.ConceptMap-search-translate"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/ConceptMap/{ConceptMapId}/$translate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/ConceptMap/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$translate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.ConceptMap-translate"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Consent/{ConsentId}/$consent-enforcement-status","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Consent/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$consent-enforcement-status)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Consent-enforcement-status"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Observation/$lastn","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Observation/\\$lastn)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Observation-lastn"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Patient/{PatientId}/$consent-enforcement-status","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Patient/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$consent-enforcement-status)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Patient-consent-enforcement-status"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/Patient/{PatientId}/$everything","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/Patient/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$everything)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Patient-everything"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/metadata","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/metadata)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.capabilities"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.read"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.history"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}/_history/{_historyId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_history/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.vread"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:explainDataAccess","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::explainDataAccess)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.explainDataAccess"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getFHIRStoreMetrics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getFHIRStoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getFHIRStoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:batchGet","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:batchGet)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.batchGet"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getHL7v2StoreMetrics","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getHL7v2StoreMetrics)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getHL7v2StoreMetrics"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.list"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.get"},{"hostname":"healthcare.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalPatch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalPatch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations/{annotationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions/{attributeDefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalPatch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.patch"},{"hostname":"healthcare.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages/{messagesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.patch"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:activate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.activate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:reject","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.reject"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:revoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.revoke"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}:archive","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.archive"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:checkDataAccess","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkDataAccess)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.checkDataAccess"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:evaluateUserConsents","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateUserConsents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.evaluateUserConsents"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:queryAccessibleData","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAccessibleData)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.queryAccessibleData"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataMapperWorkspaces/{dataMapperWorkspacesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataMapperWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dataMapperWorkspaces.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataMapperWorkspaces/{dataMapperWorkspacesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataMapperWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dataMapperWorkspaces.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:deidentify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.executeBundle"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/_search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/$validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$validate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-validate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{resourceType}/_search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search-type"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:deidentify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.rollback"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:ingest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:ingest)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.ingest"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.rollback"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.cancel"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:deidentify","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/nlp:analyzeEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/nlp:analyzeEntities)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.services.nlp.analyzeEntities"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:getIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.getIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:export","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:import","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.executeBundle"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/_search","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:export","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:import","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:ingest","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:ingest)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.ingest"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:deidentify","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}/annotations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.annotations.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:evaluate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.evaluate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/annotationStores/{annotationStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotationStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.annotationStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/attributeDefinitions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributeDefinitions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.attributeDefinitions.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consentArtifacts","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentArtifacts)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consentArtifacts.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:activate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.activate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:reject","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reject)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.reject"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/consents/{consentsId}:revoke","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.consents.revoke"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}/userDataMappings/{userDataMappingsId}:archive","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userDataMappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.userDataMappings.archive"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:checkDataAccess","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkDataAccess)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.checkDataAccess"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:evaluateUserConsents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::evaluateUserConsents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.evaluateUserConsents"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:queryAccessibleData","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAccessibleData)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.queryAccessibleData"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/consentStores/{consentStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consentStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.consentStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataMapperWorkspaces/{dataMapperWorkspacesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataMapperWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dataMapperWorkspaces.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dataMapperWorkspaces/{dataMapperWorkspacesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataMapperWorkspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dataMapperWorkspaces.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.studies.storeInstances"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}/dicomWeb/studies/{studiesId}:setBlobStorageSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomWeb/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setBlobStorageSettings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.dicomWeb.studies.setBlobStorageSettings"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:deidentify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setBlobStorageSettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setBlobStorageSettings)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setBlobStorageSettings"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/dicomStores/{dicomStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dicomStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.dicomStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.executeBundle"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/_search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.createResource"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/$validate","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/\\$validate)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.Resource-validate"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{resourceType}/_search","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/_search)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.search-type"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:applyAdminConsents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyAdminConsents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.applyAdminConsents"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:applyConsents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyConsents)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.applyConsents"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:configureSearch","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::configureSearch)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.configureSearch"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:deidentify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:exportHistory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportHistory)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.exportHistory"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:importHistory","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importHistory)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.importHistory"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.rollback"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.create"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}/messages:ingest","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/messages:ingest)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.messages.ingest"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.export"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.import"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:rollback","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.rollback"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/hl7V2Stores/{hl7V2StoresId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hl7V2Stores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.hl7V2Stores.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.operations.cancel"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:deidentify","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deidentify)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.deidentify"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.setIamPolicy"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.testIamPermissions"},{"hostname":"healthcare.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/services/nlp:analyzeEntities","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/nlp:analyzeEntities)$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.services.nlp.analyzeEntities"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalUpdate"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.update"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalUpdate"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1alpha2/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1alpha2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.update"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.conditionalUpdate"},{"hostname":"healthcare.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/fhirStores/{fhirStoresId}/fhir/{fhirId}/{fhirId1}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhirStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fhir/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.healthcare","resource_name":"healthcare.projects.locations.datasets.fhirStores.fhir.update"},{"hostname":"homegraph.googleapis.com","http_method":"DELETE","path_template":"/v1/agentUsers/{agentUsersId}","path_regex":"^(?:/v1/agentUsers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.homegraph","resource_name":"homegraph.agentUsers.delete"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:query","path_regex":"^(?:/v1/devices:query)$","service_name":"google.homegraph","resource_name":"homegraph.devices.query"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:reportStateAndNotification","path_regex":"^(?:/v1/devices:reportStateAndNotification)$","service_name":"google.homegraph","resource_name":"homegraph.devices.reportStateAndNotification"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:requestSync","path_regex":"^(?:/v1/devices:requestSync)$","service_name":"google.homegraph","resource_name":"homegraph.devices.requestSync"},{"hostname":"homegraph.googleapis.com","http_method":"POST","path_template":"/v1/devices:sync","path_regex":"^(?:/v1/devices:sync)$","service_name":"google.homegraph","resource_name":"homegraph.devices.sync"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/subjects/{subjectsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.subjects.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.organizations.roles.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}/credentials/{credentialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.credentials.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/roles/{rolesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.roles.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.delete"},{"hostname":"iam.googleapis.com","http_method":"DELETE","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.delete"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/subjects/{subjectsId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.subjects.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/roles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.organizations.roles.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.organizations.roles.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients)$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}/credentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credentials)$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.credentials.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}/credentials/{credentialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.credentials.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/namespaces/{namespacesId}/managedIdentities/{managedIdentitiesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedIdentities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.namespaces.managedIdentities.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/namespaces/{namespacesId}/managedIdentities/{managedIdentitiesId}/workloadSources/{workloadSourcesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedIdentities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.namespaces.managedIdentities.workloadSources.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/namespaces/{namespacesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.namespaces.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/roles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.projects.roles.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/roles/{rolesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.roles.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/roles","path_regex":"^(?:/v1/roles)$","service_name":"google.iam","resource_name":"iam.roles.list"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v1/roles/{rolesId}","path_regex":"^(?:/v1/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.roles.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.listPolicies"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}/operations/{operationsId}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.operations.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2beta/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.listPolicies"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.get"},{"hostname":"iam.googleapis.com","http_method":"GET","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}/operations/{operationsId}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.operations.get"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.organizations.roles.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}/credentials/{credentialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credentials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.credentials.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/roles/{rolesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.roles.patch"},{"hostname":"iam.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.patch"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/iamPolicies:lintPolicy","path_regex":"^(?:/v1/iamPolicies:lintPolicy)$","service_name":"google.iam","resource_name":"iam.iamPolicies.lintPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/iamPolicies:queryAuditableServices","path_regex":"^(?:/v1/iamPolicies:queryAuditableServices)$","service_name":"google.iam","resource_name":"iam.iamPolicies.queryAuditableServices"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}/keys/{keysId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.keys.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/providers/{providersId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.providers.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}/subjects/{subjectsId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.subjects.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:getIamPolicy","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.getIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:setIamPolicy","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.setIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:testIamPermissions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.testIamPermissions"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/workforcePools/{workforcePoolsId}:undelete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workforcePools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.locations.workforcePools.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/roles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.organizations.roles.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/roles/{rolesId}:undelete","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.organizations.roles.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/permissions:queryTestablePermissions","path_regex":"^(?:/v1/permissions:queryTestablePermissions)$","service_name":"google.iam","resource_name":"iam.permissions.queryTestablePermissions"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients)$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}/credentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credentials)$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.credentials.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/oauthClients/{oauthClientsId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.locations.oauthClients.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}/keys/{keysId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.keys.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}/providers/{providersId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/providers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.providers.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workloadIdentityPools/{workloadIdentityPoolsId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloadIdentityPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.locations.workloadIdentityPools.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/roles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles)$","service_name":"google.iam","resource_name":"iam.projects.roles.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/roles/{rolesId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.roles.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.create"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.disable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys/{keysId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.enable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}/keys:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys:upload)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.keys.upload"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.disable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.enable"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.getIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.setIamPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signBlob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signBlob)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.signBlob"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signJwt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signJwt)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.signJwt"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.testIamPermissions"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.undelete"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v1/roles:queryGrantableRoles","path_regex":"^(?:/v1/roles:queryGrantableRoles)$","service_name":"google.iam","resource_name":"iam.roles.queryGrantableRoles"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v2/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.createPolicy"},{"hostname":"iam.googleapis.com","http_method":"POST","path_template":"/v2beta/policies/{policiesId}/{policiesId1}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.createPolicy"},{"hostname":"iam.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.projects.serviceAccounts.update"},{"hostname":"iam.googleapis.com","http_method":"PUT","path_template":"/v2/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.update"},{"hostname":"iam.googleapis.com","http_method":"PUT","path_template":"/v2beta/policies/{policiesId}/{policiesId1}/{policiesId2}","path_regex":"^(?:/v2beta/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iam","resource_name":"iam.policies.update"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:generateAccessToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAccessToken)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.generateAccessToken"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:generateIdToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateIdToken)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.generateIdToken"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signBlob","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signBlob)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.signBlob"},{"hostname":"iamcredentials.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/serviceAccounts/{serviceAccountsId}:signJwt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signJwt)$","service_name":"google.iamcredentials","resource_name":"iamcredentials.projects.serviceAccounts.signJwt"},{"hostname":"iap.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients/{identityAwareProxyClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.delete"},{"hostname":"iap.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups/{destGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.delete"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands)$","service_name":"google.iap","resource_name":"iap.projects.brands.list"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands/{brandsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.brands.get"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients)$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.list"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients/{identityAwareProxyClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.get"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups)$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.list"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups/{destGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.get"},{"hostname":"iap.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}:iapSettings","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::iapSettings)$","service_name":"google.iap","resource_name":"iap.getIapSettings"},{"hostname":"iap.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups/{destGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.patch"},{"hostname":"iap.googleapis.com","http_method":"PATCH","path_template":"/v1/{v1Id}:iapSettings","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::iapSettings)$","service_name":"google.iap","resource_name":"iap.updateIapSettings"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/brands","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands)$","service_name":"google.iap","resource_name":"iap.projects.brands.create"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients)$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.create"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/brands/{brandsId}/identityAwareProxyClients/{identityAwareProxyClientsId}:resetSecret","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brands/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityAwareProxyClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetSecret)$","service_name":"google.iap","resource_name":"iap.projects.brands.identityAwareProxyClients.resetSecret"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/iap_tunnel/locations/{locationsId}/destGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iap_tunnel/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destGroups)$","service_name":"google.iap","resource_name":"iap.projects.iap_tunnel.locations.destGroups.create"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:getIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iap","resource_name":"iap.getIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:setIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iap","resource_name":"iap.setIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:testIamPermissions","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iap","resource_name":"iap.testIamPermissions"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:validateAttributeExpression","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateAttributeExpression)$","service_name":"google.iap","resource_name":"iap.validateAttributeExpression"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:getIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.iap","resource_name":"iap.getIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:setIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.iap","resource_name":"iap.setIamPolicy"},{"hostname":"iap.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:testIamPermissions","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.iap","resource_name":"iap.testIamPermissions"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1alpha/ideas","path_regex":"^(?:/v1alpha/ideas)$","service_name":"google.ideahub","resource_name":"ideahub.ideas.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/ideas","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideas)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideas.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/locales","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locales)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.locales.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/ideas","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideas)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideas.list"},{"hostname":"ideahub.googleapis.com","http_method":"GET","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/locales","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locales)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.locales.list"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/ideaStates/{ideaStatesId}","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/topicStates/{topicStatesId}","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topicStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.topicStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/ideaStates/{ideaStatesId}","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"PATCH","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/topicStates/{topicStatesId}","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topicStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.topicStates.patch"},{"hostname":"ideahub.googleapis.com","http_method":"POST","path_template":"/v1alpha/platforms/{platformsId}/properties/{propertiesId}/ideaActivities","path_regex":"^(?:/v1alpha/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaActivities)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaActivities.create"},{"hostname":"ideahub.googleapis.com","http_method":"POST","path_template":"/v1beta/platforms/{platformsId}/properties/{propertiesId}/ideaActivities","path_regex":"^(?:/v1beta/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ideaActivities)$","service_name":"google.ideahub","resource_name":"ideahub.platforms.properties.ideaActivities.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getProjects"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/accounts:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchGet)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.batchGet"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:batchGet","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchGet)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.batchGet"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/publicKeys","path_regex":"^(?:/v1/publicKeys)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getPublicKeys"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/recaptchaParams","path_regex":"^(?:/v1/recaptchaParams)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getRecaptchaParams"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v1/sessionCookiePublicKeys","path_regex":"^(?:/v1/sessionCookiePublicKeys)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getSessionCookiePublicKeys"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/defaultSupportedIdps","path_regex":"^(?:/v2/defaultSupportedIdps)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.defaultSupportedIdps.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/passwordPolicy","path_regex":"^(?:/v2/passwordPolicy)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getPasswordPolicy"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/config","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.getConfig"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.list"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.get"},{"hostname":"identitytoolkit.googleapis.com","http_method":"GET","path_template":"/v2/recaptchaConfig","path_regex":"^(?:/v2/recaptchaConfig)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.getRecaptchaConfig"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/config","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.updateConfig"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs/{defaultSupportedIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs/{inboundSamlConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs/{oauthIdpConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.patch"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:createAuthUri","path_regex":"^(?:/v1/accounts:createAuthUri)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.createAuthUri"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:delete","path_regex":"^(?:/v1/accounts:delete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:issueSamlResponse","path_regex":"^(?:/v1/accounts:issueSamlResponse)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.issueSamlResponse"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:lookup","path_regex":"^(?:/v1/accounts:lookup)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.lookup"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:resetPassword","path_regex":"^(?:/v1/accounts:resetPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.resetPassword"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:sendOobCode","path_regex":"^(?:/v1/accounts:sendOobCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.sendOobCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:sendVerificationCode","path_regex":"^(?:/v1/accounts:sendVerificationCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.sendVerificationCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithCustomToken","path_regex":"^(?:/v1/accounts:signInWithCustomToken)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithCustomToken"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithEmailLink","path_regex":"^(?:/v1/accounts:signInWithEmailLink)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithEmailLink"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithGameCenter","path_regex":"^(?:/v1/accounts:signInWithGameCenter)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithGameCenter"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithIdp","path_regex":"^(?:/v1/accounts:signInWithIdp)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithIdp"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithPassword","path_regex":"^(?:/v1/accounts:signInWithPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithPassword"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signInWithPhoneNumber","path_regex":"^(?:/v1/accounts:signInWithPhoneNumber)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signInWithPhoneNumber"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:signUp","path_regex":"^(?:/v1/accounts:signUp)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.signUp"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:update","path_regex":"^(?:/v1/accounts:update)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.update"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/accounts:verifyIosClient","path_regex":"^(?:/v1/accounts:verifyIosClient)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.verifyIosClient"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchCreate)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.batchCreate"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchDelete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.batchDelete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:delete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:lookup)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.lookup"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:query)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.query"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:sendOobCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:sendOobCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.sendOobCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/accounts:update","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:update)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.accounts.update"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchCreate)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.batchCreate"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:batchDelete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.batchDelete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:delete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:delete)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.delete"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:lookup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:lookup)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.lookup"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:query)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.query"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:sendOobCode","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:sendOobCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.sendOobCode"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}/accounts:update","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts:update)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.accounts.update"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/tenants/{tenantsId}:createSessionCookie","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::createSessionCookie)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.createSessionCookie"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:createSessionCookie","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::createSessionCookie)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.createSessionCookie"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:queryAccounts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryAccounts)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.queryAccounts"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaEnrollment:finalize","path_regex":"^(?:/v2/accounts/mfaEnrollment:finalize)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaEnrollment.finalize"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaEnrollment:start","path_regex":"^(?:/v2/accounts/mfaEnrollment:start)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaEnrollment.start"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaEnrollment:withdraw","path_regex":"^(?:/v2/accounts/mfaEnrollment:withdraw)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaEnrollment.withdraw"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaSignIn:finalize","path_regex":"^(?:/v2/accounts/mfaSignIn:finalize)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaSignIn.finalize"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts/mfaSignIn:start","path_regex":"^(?:/v2/accounts/mfaSignIn:start)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.mfaSignIn.start"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/accounts:revokeToken","path_regex":"^(?:/v2/accounts:revokeToken)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.accounts.revokeToken"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.defaultSupportedIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/identityPlatform:initializeAuth","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/identityPlatform:initializeAuth)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.identityPlatform.initializeAuth"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.inboundSamlConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.oauthIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/defaultSupportedIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultSupportedIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.defaultSupportedIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/inboundSamlConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inboundSamlConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.inboundSamlConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}/oauthIdpConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/oauthIdpConfigs)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.oauthIdpConfigs.create"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.getIamPolicy"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.setIamPolicy"},{"hostname":"identitytoolkit.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/tenants/{tenantsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.projects.tenants.testIamPermissions"},{"hostname":"ids.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.delete"},{"hostname":"ids.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.delete"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.ids","resource_name":"ids.projects.locations.list"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.get"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.list"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.get"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.getIamPolicy"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.list"},{"hostname":"ids.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.get"},{"hostname":"ids.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.patch"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.create"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.setIamPolicy"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpoints/{endpointsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ids","resource_name":"ids.projects.locations.endpoints.testIamPermissions"},{"hostname":"ids.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ids","resource_name":"ids.projects.locations.operations.cancel"},{"hostname":"indexing.googleapis.com","http_method":"GET","path_template":"/v3/urlNotifications/metadata","path_regex":"^(?:/v3/urlNotifications/metadata)$","service_name":"google.indexing","resource_name":"indexing.urlNotifications.getMetadata"},{"hostname":"indexing.googleapis.com","http_method":"POST","path_template":"/v3/urlNotifications:publish","path_regex":"^(?:/v3/urlNotifications:publish)$","service_name":"google.indexing","resource_name":"indexing.urlNotifications.publish"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.delete"},{"hostname":"integrations.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.delete"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/callback:generateToken","path_regex":"^(?:/v1/callback:generateToken)$","service_name":"google.integrations","resource_name":"integrations.callback.generateToken"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/connectorPlatformRegions:enumerate","path_regex":"^(?:/v1/connectorPlatformRegions:enumerate)$","service_name":"google.integrations","resource_name":"integrations.connectorPlatformRegions.enumerate"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/clientmetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientmetadata)$","service_name":"google.integrations","resource_name":"integrations.projects.getClientmetadata"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.getClients"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.getConnectionSchemaMetadata"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeActionSchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeActionSchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeActionSchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeEntitySchemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeEntitySchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeEntitySchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executionsnapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionsnapshots)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executionsnapshots.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executionsnapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executionsnapshots)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executionsnapshots.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:getBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.getBundle"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}:listTaskEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTaskEntities)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.listTaskEntities"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:listTaskEntities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listTaskEntities)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.listTaskEntities"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/callback:generateToken","path_regex":"^(?:/v1alpha/callback:generateToken)$","service_name":"google.integrations","resource_name":"integrations.callback.generateToken"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/connectorPlatformRegions:enumerate","path_regex":"^(?:/v1alpha/connectorPlatformRegions:enumerate)$","service_name":"google.integrations","resource_name":"integrations.connectorPlatformRegions.enumerate"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/connectionSchemaMetadata","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionSchemaMetadata)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.getConnectionSchemaMetadata"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeActionSchemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeActionSchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeActionSchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/connections/{connectionsId}/runtimeEntitySchemas","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeEntitySchemas)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.connections.runtimeEntitySchemas.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:download","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::download)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.download"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrationtemplates/{integrationtemplatesId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrationtemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrationtemplates.versions.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrationtemplates/{integrationtemplatesId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrationtemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrationtemplates.versions.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.get"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.list"},{"hostname":"integrations.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.get"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:updateBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.updateBundle"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs/{authConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates/{certificatesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.patch"},{"hostname":"integrations.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels/{sfdcChannelsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.patch"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appsScriptProjects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/appsScriptProjects:link","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects:link)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.link"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.certificates.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clients:deprovision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients:deprovision)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.clients.deprovision"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clients:provision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients:provision)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.clients.provision"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/cloudFunctions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloudFunctions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.cloudFunctions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:archive","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.archive"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:deactivate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.deactivate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.validate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:test","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::test)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.test"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/cloudFunctions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloudFunctions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.cloudFunctions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.cancel"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:archive","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.archive"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:deactivate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.deactivate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:takeoverEditLock","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::takeoverEditLock)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.takeoverEditLock"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.validate"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:archiveBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archiveBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.archiveBundle"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:test","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::test)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.test"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}:createBundle","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::createBundle)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.createBundle"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appsScriptProjects","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/appsScriptProjects:link","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/appsScriptProjects:link)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.appsScriptProjects.link"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:takeoverEditLock","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::takeoverEditLock)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.takeoverEditLock"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:executeEvent","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeEvent)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.executeEvent"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/authConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authConfigs)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.authConfigs.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/certificates","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.certificates.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:lift","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lift)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.lift"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}/suspensions/{suspensionsId}:resolve","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.suspensions.resolve"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.executions.cancel"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:publish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.publish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:takeoverEditLock","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::takeoverEditLock)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.takeoverEditLock"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions/{versionsId}:unpublish","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::unpublish)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.unpublish"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}/versions:upload","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:upload)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.versions.upload"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:execute","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::execute)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.execute"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrations/{integrationsId}:schedule","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::schedule)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrations.schedule"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/integrationtemplates/{integrationtemplatesId}/versions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/integrationtemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.integrationtemplates.versions.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/products/{productsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.products.sfdcInstances.sfdcChannels.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.create"},{"hostname":"integrations.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/sfdcInstances/{sfdcInstancesId}/sfdcChannels","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcInstances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sfdcChannels)$","service_name":"google.integrations","resource_name":"integrations.projects.locations.sfdcInstances.sfdcChannels.create"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v2/companies/{companiesId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v2/jobs/{jobsId}","path_regex":"^(?:/v2/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3p1beta1/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v3p1beta1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies/{companiesId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.delete"},{"hostname":"jobs.googleapis.com","http_method":"DELETE","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs/{jobsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.delete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.jobs","resource_name":"jobs.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/companies/{companiesId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/companies/{companiesId}/jobs","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.companies.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/jobs","path_regex":"^(?:/v2/jobs)$","service_name":"google.jobs","resource_name":"jobs.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2/jobs/{jobsId}","path_regex":"^(?:/v2/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v2:complete","path_regex":"^(?:/v2:complete)$","service_name":"google.jobs","resource_name":"jobs.complete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/companies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/jobs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}:complete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.jobs","resource_name":"jobs.projects.complete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/companies","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/jobs","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.operations.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v3p1beta1/projects/{projectsId}:complete","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.jobs","resource_name":"jobs.projects.complete"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.operations.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies/{companiesId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.list"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs/{jobsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.get"},{"hostname":"jobs.googleapis.com","http_method":"GET","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}:completeQuery","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.completeQuery"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v2/companies/{companiesId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v2/jobs/{jobsId}","path_regex":"^(?:/v2/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3p1beta1/projects/{projectsId}/companies/{companiesId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v3p1beta1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies/{companiesId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.patch"},{"hostname":"jobs.googleapis.com","http_method":"PATCH","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs/{jobsId}","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.patch"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.jobs","resource_name":"jobs.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs","path_regex":"^(?:/v2/jobs)$","service_name":"google.jobs","resource_name":"jobs.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:batchDelete","path_regex":"^(?:/v2/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:deleteByFilter","path_regex":"^(?:/v2/jobs:deleteByFilter)$","service_name":"google.jobs","resource_name":"jobs.jobs.deleteByFilter"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:histogram","path_regex":"^(?:/v2/jobs:histogram)$","service_name":"google.jobs","resource_name":"jobs.jobs.histogram"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:search","path_regex":"^(?:/v2/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v2/jobs:searchForAlert","path_regex":"^(?:/v2/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.jobs.searchForAlert"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/clientEvents","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientEvents)$","service_name":"google.jobs","resource_name":"jobs.projects.clientEvents.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/companies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs:batchDelete","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs:search","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/jobs:searchForAlert","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.searchForAlert"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/clientEvents","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientEvents)$","service_name":"google.jobs","resource_name":"jobs.projects.clientEvents.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/companies","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs:batchDelete","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs:search","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v3p1beta1/projects/{projectsId}/jobs:searchForAlert","path_regex":"^(?:/v3p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.projects.jobs.searchForAlert"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/clientEvents","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientEvents)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.clientEvents.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/companies","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companies)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.companies.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.create"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:batchCreate","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchCreate)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.batchCreate"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:batchDelete","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchDelete)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.batchDelete"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:batchUpdate","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:batchUpdate)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.batchUpdate"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:search","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:search)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.search"},{"hostname":"jobs.googleapis.com","http_method":"POST","path_template":"/v4/projects/{projectsId}/tenants/{tenantsId}/jobs:searchForAlert","path_regex":"^(?:/v4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs:searchForAlert)$","service_name":"google.jobs","resource_name":"jobs.projects.tenants.jobs.searchForAlert"},{"hostname":"keep.googleapis.com","http_method":"DELETE","path_template":"/v1/notes/{notesId}","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.keep","resource_name":"keep.notes.delete"},{"hostname":"keep.googleapis.com","http_method":"GET","path_template":"/v1/notes","path_regex":"^(?:/v1/notes)$","service_name":"google.keep","resource_name":"keep.notes.list"},{"hostname":"keep.googleapis.com","http_method":"GET","path_template":"/v1/notes/{notesId}","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.keep","resource_name":"keep.notes.get"},{"hostname":"keep.googleapis.com","http_method":"GET","path_template":"/v1/notes/{notesId}/attachments/{attachmentsId}","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.keep","resource_name":"keep.media.download"},{"hostname":"keep.googleapis.com","http_method":"POST","path_template":"/v1/notes","path_regex":"^(?:/v1/notes)$","service_name":"google.keep","resource_name":"keep.notes.create"},{"hostname":"keep.googleapis.com","http_method":"POST","path_template":"/v1/notes/{notesId}/permissions:batchCreate","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchCreate)$","service_name":"google.keep","resource_name":"keep.notes.permissions.batchCreate"},{"hostname":"keep.googleapis.com","http_method":"POST","path_template":"/v1/notes/{notesId}/permissions:batchDelete","path_regex":"^(?:/v1/notes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions:batchDelete)$","service_name":"google.keep","resource_name":"keep.notes.permissions.batchDelete"},{"hostname":"kgsearch.googleapis.com","http_method":"GET","path_template":"/v1/entities:search","path_regex":"^(?:/v1/entities:search)$","service_name":"google.kgsearch","resource_name":"kgsearch.entities.search"},{"hostname":"kmsinventory.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/protectedResources:search","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/protectedResources:search)$","service_name":"google.kmsinventory","resource_name":"kmsinventory.organizations.protectedResources.search"},{"hostname":"kmsinventory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/cryptoKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys)$","service_name":"google.kmsinventory","resource_name":"kmsinventory.projects.cryptoKeys.list"},{"hostname":"kmsinventory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/keyRings/{keyRingsId}/cryptoKeys/{cryptoKeysId}/protectedResourcesSummary","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keyRings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cryptoKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/protectedResourcesSummary)$","service_name":"google.kmsinventory","resource_name":"kmsinventory.projects.locations.keyRings.cryptoKeys.getProtectedResourcesSummary"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeEntities","path_regex":"^(?:/v1/documents:analyzeEntities)$","service_name":"google.language","resource_name":"language.documents.analyzeEntities"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeEntitySentiment","path_regex":"^(?:/v1/documents:analyzeEntitySentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeEntitySentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeSentiment","path_regex":"^(?:/v1/documents:analyzeSentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeSentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:analyzeSyntax","path_regex":"^(?:/v1/documents:analyzeSyntax)$","service_name":"google.language","resource_name":"language.documents.analyzeSyntax"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:annotateText","path_regex":"^(?:/v1/documents:annotateText)$","service_name":"google.language","resource_name":"language.documents.annotateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:classifyText","path_regex":"^(?:/v1/documents:classifyText)$","service_name":"google.language","resource_name":"language.documents.classifyText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1/documents:moderateText","path_regex":"^(?:/v1/documents:moderateText)$","service_name":"google.language","resource_name":"language.documents.moderateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:analyzeEntities","path_regex":"^(?:/v1beta1/documents:analyzeEntities)$","service_name":"google.language","resource_name":"language.documents.analyzeEntities"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:analyzeSentiment","path_regex":"^(?:/v1beta1/documents:analyzeSentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeSentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:analyzeSyntax","path_regex":"^(?:/v1beta1/documents:analyzeSyntax)$","service_name":"google.language","resource_name":"language.documents.analyzeSyntax"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta1/documents:annotateText","path_regex":"^(?:/v1beta1/documents:annotateText)$","service_name":"google.language","resource_name":"language.documents.annotateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeEntities","path_regex":"^(?:/v1beta2/documents:analyzeEntities)$","service_name":"google.language","resource_name":"language.documents.analyzeEntities"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeEntitySentiment","path_regex":"^(?:/v1beta2/documents:analyzeEntitySentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeEntitySentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeSentiment","path_regex":"^(?:/v1beta2/documents:analyzeSentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeSentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:analyzeSyntax","path_regex":"^(?:/v1beta2/documents:analyzeSyntax)$","service_name":"google.language","resource_name":"language.documents.analyzeSyntax"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:annotateText","path_regex":"^(?:/v1beta2/documents:annotateText)$","service_name":"google.language","resource_name":"language.documents.annotateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:classifyText","path_regex":"^(?:/v1beta2/documents:classifyText)$","service_name":"google.language","resource_name":"language.documents.classifyText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v1beta2/documents:moderateText","path_regex":"^(?:/v1beta2/documents:moderateText)$","service_name":"google.language","resource_name":"language.documents.moderateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v2/documents:analyzeEntities","path_regex":"^(?:/v2/documents:analyzeEntities)$","service_name":"google.language","resource_name":"language.documents.analyzeEntities"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v2/documents:analyzeSentiment","path_regex":"^(?:/v2/documents:analyzeSentiment)$","service_name":"google.language","resource_name":"language.documents.analyzeSentiment"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v2/documents:annotateText","path_regex":"^(?:/v2/documents:annotateText)$","service_name":"google.language","resource_name":"language.documents.annotateText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v2/documents:classifyText","path_regex":"^(?:/v2/documents:classifyText)$","service_name":"google.language","resource_name":"language.documents.classifyText"},{"hostname":"language.googleapis.com","http_method":"POST","path_template":"/v2/documents:moderateText","path_regex":"^(?:/v2/documents:moderateText)$","service_name":"google.language","resource_name":"language.documents.moderateText"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves","path_regex":"^(?:/v1/shelves)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.list"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves/{shelvesId}","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.get"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves/{shelvesId}/books","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.list"},{"hostname":"libraryagent.googleapis.com","http_method":"GET","path_template":"/v1/shelves/{shelvesId}/books/{booksId}","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.get"},{"hostname":"libraryagent.googleapis.com","http_method":"POST","path_template":"/v1/shelves/{shelvesId}/books/{booksId}:borrow","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::borrow)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.borrow"},{"hostname":"libraryagent.googleapis.com","http_method":"POST","path_template":"/v1/shelves/{shelvesId}/books/{booksId}:return","path_regex":"^(?:/v1/shelves/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/books/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::return)$","service_name":"google.libraryagent","resource_name":"libraryagent.shelves.books.return"},{"hostname":"licensing.googleapis.com","http_method":"DELETE","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.delete"},{"hostname":"licensing.googleapis.com","http_method":"GET","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.get"},{"hostname":"licensing.googleapis.com","http_method":"GET","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/users","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.listForProductAndSku"},{"hostname":"licensing.googleapis.com","http_method":"GET","path_template":"/apps/licensing/v1/product/{productId}/users","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.listForProduct"},{"hostname":"licensing.googleapis.com","http_method":"PATCH","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.patch"},{"hostname":"licensing.googleapis.com","http_method":"POST","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user)$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.insert"},{"hostname":"licensing.googleapis.com","http_method":"PUT","path_template":"/apps/licensing/v1/product/{productId}/sku/{skuId}/user/{userId}","path_regex":"^(?:/apps/licensing/v1/product/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sku/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.licensing","resource_name":"licensing.licenseAssignments.update"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.list"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.get"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.operations.list"},{"hostname":"lifesciences.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.operations.get"},{"hostname":"lifesciences.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.operations.cancel"},{"hostname":"lifesciences.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/pipelines:run","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pipelines:run)$","service_name":"google.lifesciences","resource_name":"lifesciences.projects.locations.pipelines.run"},{"hostname":"localservices.googleapis.com","http_method":"GET","path_template":"/v1/accountReports:search","path_regex":"^(?:/v1/accountReports:search)$","service_name":"google.localservices","resource_name":"localservices.accountReports.search"},{"hostname":"localservices.googleapis.com","http_method":"GET","path_template":"/v1/detailedLeadReports:search","path_regex":"^(?:/v1/detailedLeadReports:search)$","service_name":"google.localservices","resource_name":"localservices.detailedLeadReports.search"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.savedQueries.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/logs/{logsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.savedQueries.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/logs/{logsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.savedQueries.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/logs/{logsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.savedQueries.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/logs/{logsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.exclusions.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/logs/{logsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.logs.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2/{v2Id}/{v2Id1}/sinks/{sinksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.delete"},{"hostname":"logging.googleapis.com","http_method":"DELETE","path_template":"/v2beta1/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.delete"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices)$","service_name":"google.logging","resource_name":"logging.projects.logServices.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/indexes","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/indexes)$","service_name":"google.logging","resource_name":"logging.projects.logServices.indexes.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logs","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.projects.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/cmekSettings","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.billingAccounts.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/recentQueries","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recentQueries)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.recentQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.savedQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.savedQueries.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/logs","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.billingAccounts.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/settings","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.billingAccounts.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/cmekSettings","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.folders.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/exclusions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.folders.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.folders.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.folders.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/recentQueries","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recentQueries)$","service_name":"google.logging","resource_name":"logging.folders.locations.recentQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.folders.locations.savedQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.savedQueries.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/logs","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.folders.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/settings","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.folders.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/sinks","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.folders.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/monitoredResourceDescriptors","path_regex":"^(?:/v2/monitoredResourceDescriptors)$","service_name":"google.logging","resource_name":"logging.monitoredResourceDescriptors.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/cmekSettings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.organizations.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/exclusions","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.organizations.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.organizations.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/recentQueries","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recentQueries)$","service_name":"google.logging","resource_name":"logging.organizations.locations.recentQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.organizations.locations.savedQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.savedQueries.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/logs","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.organizations.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/settings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.organizations.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/sinks","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.organizations.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/cmekSettings","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.projects.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/exclusions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.projects.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.projects.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}/logs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.projects.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/recentQueries","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recentQueries)$","service_name":"google.logging","resource_name":"logging.projects.locations.recentQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.projects.locations.savedQueries.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.savedQueries.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/logs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.projects.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/metrics","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/settings","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.projects.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/sinks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/cmekSettings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.getCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/exclusions","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.exclusions.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.exclusions.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.logging","resource_name":"logging.locations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.locations.buckets.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links/{linksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/operations","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.logging","resource_name":"logging.locations.operations.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.operations.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/logs","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs)$","service_name":"google.logging","resource_name":"logging.logs.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/settings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.getSettings"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/sinks","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/{v2Id1}/sinks/{sinksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/monitoredResourceDescriptors","path_regex":"^(?:/v2beta1/monitoredResourceDescriptors)$","service_name":"google.logging","resource_name":"logging.monitoredResourceDescriptors.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/metrics","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.get"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/sinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.list"},{"hostname":"logging.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.get"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.savedQueries.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.locations.savedQueries.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/settings","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.folders.updateSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/cmekSettings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.organizations.updateCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.locations.savedQueries.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/settings","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.organizations.updateSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/savedQueries/{savedQueriesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.locations.savedQueries.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/cmekSettings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cmekSettings)$","service_name":"google.logging","resource_name":"logging.updateCmekSettings"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/exclusions/{exclusionsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.exclusions.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.patch"},{"hostname":"logging.googleapis.com","http_method":"PATCH","path_template":"/v2/{v2Id}/{v2Id1}/settings","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.logging","resource_name":"logging.updateSettings"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/entries:write","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries:write)$","service_name":"google.logging","resource_name":"logging.projects.logs.entries.write"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/entries:write","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries:write)$","service_name":"google.logging","resource_name":"logging.projects.logs.entries.write"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/exclusions","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.billingAccounts.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.billingAccounts.locations.savedQueries.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:copy","path_regex":"^(?:/v2/entries:copy)$","service_name":"google.logging","resource_name":"logging.entries.copy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:list","path_regex":"^(?:/v2/entries:list)$","service_name":"google.logging","resource_name":"logging.entries.list"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:tail","path_regex":"^(?:/v2/entries:tail)$","service_name":"google.logging","resource_name":"logging.entries.tail"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/entries:write","path_regex":"^(?:/v2/entries:write)$","service_name":"google.logging","resource_name":"logging.entries.write"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/exclusions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.folders.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:getIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.getIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:setIamPolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.setIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:testIamPermissions","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.views.testIamPermissions"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.folders.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.folders.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.folders.locations.savedQueries.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/sinks","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.folders.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/exclusions","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.organizations.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:getIamPolicy","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.getIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:setIamPolicy","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.setIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:testIamPermissions","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.views.testIamPermissions"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.organizations.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.organizations.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.organizations.locations.savedQueries.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/sinks","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.organizations.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/exclusions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.projects.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.getIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.setIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.views.testIamPermissions"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.projects.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.projects.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/savedQueries","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.logging","resource_name":"logging.projects.locations.savedQueries.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/metrics","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/sinks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/exclusions","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exclusions)$","service_name":"google.logging","resource_name":"logging.exclusions.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets)$","service_name":"google.logging","resource_name":"logging.locations.buckets.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/links","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/links)$","service_name":"google.logging","resource_name":"logging.locations.buckets.links.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views)$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:getIamPolicy","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.getIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:setIamPolicy","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.setIamPolicy"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}/views/{viewsId}:testIamPermissions","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/views/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.logging","resource_name":"logging.locations.buckets.views.testIamPermissions"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}:undelete","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.logging","resource_name":"logging.locations.buckets.undelete"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets/{bucketsId}:updateAsync","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateAsync)$","service_name":"google.logging","resource_name":"logging.locations.buckets.updateAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/buckets:createAsync","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buckets:createAsync)$","service_name":"google.logging","resource_name":"logging.locations.buckets.createAsync"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.logging","resource_name":"logging.locations.operations.cancel"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/{v2Id1}/sinks","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/entries:list","path_regex":"^(?:/v2beta1/entries:list)$","service_name":"google.logging","resource_name":"logging.entries.list"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/entries:write","path_regex":"^(?:/v2beta1/entries:write)$","service_name":"google.logging","resource_name":"logging.entries.write"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/metrics","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.logging","resource_name":"logging.projects.metrics.create"},{"hostname":"logging.googleapis.com","http_method":"POST","path_template":"/v2beta1/projects/{projectsId}/sinks","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks)$","service_name":"google.logging","resource_name":"logging.projects.sinks.create"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v1beta3/projects/{projectsId}/logServices/{logServicesId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logServices.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v1beta3/projects/{projectsId}/logs/{logsId}/sinks/{sinksId}","path_regex":"^(?:/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/logs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.logs.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/billingAccounts/{billingAccountsId}/sinks/{sinksId}","path_regex":"^(?:/v2/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.billingAccounts.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/folders/{foldersId}/sinks/{sinksId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.folders.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/organizations/{organizationsId}/sinks/{sinksId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.organizations.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2/{v2Id}/{v2Id1}/sinks/{sinksId}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.sinks.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2beta1/projects/{projectsId}/metrics/{metricsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.metrics.update"},{"hostname":"logging.googleapis.com","http_method":"PUT","path_template":"/v2beta1/projects/{projectsId}/sinks/{sinksId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.logging","resource_name":"logging.projects.sinks.update"},{"hostname":"looker.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.delete"},{"hostname":"looker.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.looker","resource_name":"looker.projects.locations.operations.delete"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.looker","resource_name":"looker.projects.locations.list"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.looker","resource_name":"looker.projects.locations.get"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.list"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.get"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.backups.getIamPolicy"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.getIamPolicy"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.looker","resource_name":"looker.projects.locations.operations.list"},{"hostname":"looker.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.looker","resource_name":"looker.projects.locations.operations.get"},{"hostname":"looker.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.patch"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.create"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.backups.setIamPolicy"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.backups.testIamPermissions"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.export"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.import"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restart)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.restart"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.setIamPolicy"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.looker","resource_name":"looker.projects.locations.instances.testIamPermissions"},{"hostname":"looker.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.looker","resource_name":"looker.projects.locations.operations.cancel"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.delete"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations/{sqlIntegrationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations/{sqlIntegrationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/sqlIntegrations/{sqlIntegrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sqlIntegrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.sqlIntegrations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.list"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.get"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.getIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.get"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.updateLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.updateLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/ldapssettings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ldapssettings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.updateLdapssettings"},{"hostname":"managedidentities.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.patch"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:attachTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.attachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:checkMigrationPermission","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkMigrationPermission)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.checkMigrationPermission"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:detachTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.detachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:disableMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.disableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:domainJoinMachine","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::domainJoinMachine)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.domainJoinMachine"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:enableMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.enableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:extendSchema","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extendSchema)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.extendSchema"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:reconfigureTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reconfigureTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.reconfigureTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:resetAdminPassword","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAdminPassword)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.resetAdminPassword"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.restore"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/domains/{domainsId}:validateTrust","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.validateTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.cancel"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/peerings/{peeringsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:attachTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.attachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:checkMigrationPermission","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkMigrationPermission)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.checkMigrationPermission"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:detachTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.detachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:disableMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.disableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:domainJoinMachine","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::domainJoinMachine)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.domainJoinMachine"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:enableMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.enableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:extendSchema","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extendSchema)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.extendSchema"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:reconfigureTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reconfigureTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.reconfigureTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:resetAdminPassword","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAdminPassword)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.resetAdminPassword"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:restore","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.restore"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/domains/{domainsId}:validateTrust","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.validateTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.cancel"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/peerings/{peeringsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.backups.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:attachTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.attachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:checkMigrationPermission","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkMigrationPermission)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.checkMigrationPermission"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:detachTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detachTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.detachTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:disableMigration","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.disableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:domainJoinMachine","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::domainJoinMachine)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.domainJoinMachine"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:enableMigration","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableMigration)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.enableMigration"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:extendSchema","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extendSchema)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.extendSchema"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:reconfigureTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reconfigureTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.reconfigureTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:resetAdminPassword","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetAdminPassword)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.resetAdminPassword"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:restore","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.restore"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.testIamPermissions"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/domains/{domainsId}:validateTrust","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/domains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validateTrust)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.domains.validateTrust"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.operations.cancel"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.create"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.setIamPolicy"},{"hostname":"managedidentities.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/peerings/{peeringsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/peerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.managedidentities","resource_name":"managedidentities.projects.locations.global.peerings.testIamPermissions"},{"hostname":"manufacturers.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications/{productCertificationsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.delete"},{"hostname":"manufacturers.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/products/{productsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.delete"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications)$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.list"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications/{productCertificationsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.get"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/products","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.list"},{"hostname":"manufacturers.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/products/{productsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.get"},{"hostname":"manufacturers.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/languages/{languagesId}/productCertifications/{productCertificationsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productCertifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.languages.productCertifications.patch"},{"hostname":"manufacturers.googleapis.com","http_method":"PUT","path_template":"/v1/accounts/{accountsId}/products/{productsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.manufacturers","resource_name":"manufacturers.accounts.products.update"},{"hostname":"marketingplatformadmin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/organizations/{organizationsId}/analyticsAccountLinks/{analyticsAccountLinksId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyticsAccountLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.marketingplatformadmin","resource_name":"marketingplatformadmin.organizations.analyticsAccountLinks.delete"},{"hostname":"marketingplatformadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.marketingplatformadmin","resource_name":"marketingplatformadmin.organizations.get"},{"hostname":"marketingplatformadmin.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/analyticsAccountLinks","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyticsAccountLinks)$","service_name":"google.marketingplatformadmin","resource_name":"marketingplatformadmin.organizations.analyticsAccountLinks.list"},{"hostname":"marketingplatformadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/analyticsAccountLinks","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyticsAccountLinks)$","service_name":"google.marketingplatformadmin","resource_name":"marketingplatformadmin.organizations.analyticsAccountLinks.create"},{"hostname":"marketingplatformadmin.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/analyticsAccountLinks/{analyticsAccountLinksId}:setPropertyServiceLevel","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/analyticsAccountLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setPropertyServiceLevel)$","service_name":"google.marketingplatformadmin","resource_name":"marketingplatformadmin.organizations.analyticsAccountLinks.setPropertyServiceLevel"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords","path_regex":"^(?:/v2/conferenceRecords)$","service_name":"google.meet","resource_name":"meet.conferenceRecords.list"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.conferenceRecords.get"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/participants","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants)$","service_name":"google.meet","resource_name":"meet.conferenceRecords.participants.list"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/participants/{participantsId}","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.conferenceRecords.participants.get"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/participants/{participantsId}/participantSessions","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participantSessions)$","service_name":"google.meet","resource_name":"meet.conferenceRecords.participants.participantSessions.list"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/participants/{participantsId}/participantSessions/{participantSessionsId}","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participants/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/participantSessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.conferenceRecords.participants.participantSessions.get"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/recordings","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recordings)$","service_name":"google.meet","resource_name":"meet.conferenceRecords.recordings.list"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/recordings/{recordingsId}","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recordings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.conferenceRecords.recordings.get"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/transcripts","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transcripts)$","service_name":"google.meet","resource_name":"meet.conferenceRecords.transcripts.list"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/transcripts/{transcriptsId}","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transcripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.conferenceRecords.transcripts.get"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/transcripts/{transcriptsId}/entries","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transcripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries)$","service_name":"google.meet","resource_name":"meet.conferenceRecords.transcripts.entries.list"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/conferenceRecords/{conferenceRecordsId}/transcripts/{transcriptsId}/entries/{entriesId}","path_regex":"^(?:/v2/conferenceRecords/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transcripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.conferenceRecords.transcripts.entries.get"},{"hostname":"meet.googleapis.com","http_method":"GET","path_template":"/v2/spaces/{spacesId}","path_regex":"^(?:/v2/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.spaces.get"},{"hostname":"meet.googleapis.com","http_method":"PATCH","path_template":"/v2/spaces/{spacesId}","path_regex":"^(?:/v2/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.meet","resource_name":"meet.spaces.patch"},{"hostname":"meet.googleapis.com","http_method":"POST","path_template":"/v2/spaces","path_regex":"^(?:/v2/spaces)$","service_name":"google.meet","resource_name":"meet.spaces.create"},{"hostname":"meet.googleapis.com","http_method":"POST","path_template":"/v2/spaces/{spacesId}:endActiveConference","path_regex":"^(?:/v2/spaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::endActiveConference)$","service_name":"google.meet","resource_name":"meet.spaces.endActiveConference"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.delete"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.delete"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.delete"},{"hostname":"memcache.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.delete"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.get"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.list"},{"hostname":"memcache.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.get"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.patch"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.updateParameters"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.patch"},{"hostname":"memcache.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateParameters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.updateParameters"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.create"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:applyParameters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.applyParameters"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.rescheduleMaintenance"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.upgrade"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.cancel"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.create"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:applyParameters","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyParameters)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.applyParameters"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:applySoftwareUpdate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applySoftwareUpdate)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.applySoftwareUpdate"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.rescheduleMaintenance"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.instances.upgrade"},{"hostname":"memcache.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.memcache","resource_name":"memcache.projects.locations.operations.cancel"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/accounts/v1beta/accounts/{accountsId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/accounts/v1beta/accounts/{accountsId}/regions/{regionsId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.regions.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/accounts/v1beta/accounts/{accountsId}/users/{usersId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.users.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/conversions/v1beta/accounts/{accountsId}/conversionSources/{conversionSourcesId}","path_regex":"^(?:/conversions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.conversionSources.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/datasources/v1beta/accounts/{accountsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/datasources/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.dataSources.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/inventories/v1beta/accounts/{accountsId}/products/{productsId}/localInventories/{localInventoriesId}","path_regex":"^(?:/inventories/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/localInventories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.localInventories.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/inventories/v1beta/accounts/{accountsId}/products/{productsId}/regionalInventories/{regionalInventoriesId}","path_regex":"^(?:/inventories/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalInventories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.regionalInventories.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/lfp/v1beta/accounts/{accountsId}/lfpStores/{lfpStoresId}","path_regex":"^(?:/lfp/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lfpStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.lfpStores.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/notifications/v1beta/accounts/{accountsId}/notificationsubscriptions/{notificationsubscriptionsId}","path_regex":"^(?:/notifications/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationsubscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.notificationsubscriptions.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"DELETE","path_template":"/products/v1beta/accounts/{accountsId}/productInputs/{productInputsId}","path_regex":"^(?:/products/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productInputs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.productInputs.delete"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts","path_regex":"^(?:/accounts/v1beta/accounts)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/businessIdentity","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businessIdentity)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.businessIdentity.getBusinessIdentity"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/businessInfo","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businessInfo)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.businessInfo.getBusinessInfo"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/homepage","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/homepage)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.homepage.getHomepage"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/issues","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/issues)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.issues.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/onlineReturnPolicies","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/onlineReturnPolicies)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.onlineReturnPolicies.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/onlineReturnPolicies/{onlineReturnPoliciesId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/onlineReturnPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.onlineReturnPolicies.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/programs","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/programs)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.programs.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/programs/{programsId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/programs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.programs.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/regions","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.regions.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/regions/{regionsId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.regions.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/shippingSettings","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingSettings)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.shippingSettings.getShippingSettings"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/termsOfServiceAgreementStates/{termsOfServiceAgreementStatesId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/termsOfServiceAgreementStates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.termsOfServiceAgreementStates.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/termsOfServiceAgreementStates:retrieveForApplication","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/termsOfServiceAgreementStates:retrieveForApplication)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.termsOfServiceAgreementStates.retrieveForApplication"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/users","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.users.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/users/{usersId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.users.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}/users/{usersId}/emailPreferences","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/emailPreferences)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.emailpreferences.getEmailPreferences"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/accounts/{accountsId}:listSubaccounts","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSubaccounts)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.listSubaccounts"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/termsOfService/{termsOfServiceId}","path_regex":"^(?:/accounts/v1beta/termsOfService/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.termsOfService.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/termsOfService/{termsOfServiceId}:accept","path_regex":"^(?:/accounts/v1beta/termsOfService/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.merchantapi","resource_name":"merchantapi.termsOfService.accept"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/accounts/v1beta/termsOfService:retrieveLatest","path_regex":"^(?:/accounts/v1beta/termsOfService:retrieveLatest)$","service_name":"google.merchantapi","resource_name":"merchantapi.termsOfService.retrieveLatest"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/conversions/v1beta/accounts/{accountsId}/conversionSources","path_regex":"^(?:/conversions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionSources)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.conversionSources.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/conversions/v1beta/accounts/{accountsId}/conversionSources/{conversionSourcesId}","path_regex":"^(?:/conversions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.conversionSources.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/datasources/v1beta/accounts/{accountsId}/dataSources","path_regex":"^(?:/datasources/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.dataSources.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/datasources/v1beta/accounts/{accountsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/datasources/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.dataSources.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/inventories/v1beta/accounts/{accountsId}/products/{productsId}/localInventories","path_regex":"^(?:/inventories/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/localInventories)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.localInventories.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/inventories/v1beta/accounts/{accountsId}/products/{productsId}/regionalInventories","path_regex":"^(?:/inventories/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalInventories)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.regionalInventories.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/lfp/v1beta/accounts/{accountsId}/lfpStores","path_regex":"^(?:/lfp/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lfpStores)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.lfpStores.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/lfp/v1beta/accounts/{accountsId}/lfpStores/{lfpStoresId}","path_regex":"^(?:/lfp/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lfpStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.lfpStores.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/notifications/v1beta/accounts/{accountsId}/notificationsubscriptions","path_regex":"^(?:/notifications/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationsubscriptions)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.notificationsubscriptions.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/notifications/v1beta/accounts/{accountsId}/notificationsubscriptions/{notificationsubscriptionsId}","path_regex":"^(?:/notifications/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationsubscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.notificationsubscriptions.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/products/v1beta/accounts/{accountsId}/products","path_regex":"^(?:/products/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/products/v1beta/accounts/{accountsId}/products/{productsId}","path_regex":"^(?:/products/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/promotions/v1beta/accounts/{accountsId}/promotions","path_regex":"^(?:/promotions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.promotions.list"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/promotions/v1beta/accounts/{accountsId}/promotions/{promotionsId}","path_regex":"^(?:/promotions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.promotions.get"},{"hostname":"merchantapi.googleapis.com","http_method":"GET","path_template":"/quota/v1beta/accounts/{accountsId}/quotas","path_regex":"^(?:/quota/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/quotas)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.quotas.list"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/accounts/v1beta/accounts/{accountsId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.patch"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/accounts/v1beta/accounts/{accountsId}/businessIdentity","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businessIdentity)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.businessIdentity.updateBusinessIdentity"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/accounts/v1beta/accounts/{accountsId}/businessInfo","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businessInfo)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.businessInfo.updateBusinessInfo"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/accounts/v1beta/accounts/{accountsId}/homepage","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/homepage)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.homepage.updateHomepage"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/accounts/v1beta/accounts/{accountsId}/regions/{regionsId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.regions.patch"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/accounts/v1beta/accounts/{accountsId}/users/{usersId}","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.users.patch"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/accounts/v1beta/accounts/{accountsId}/users/{usersId}/emailPreferences","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/emailPreferences)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.emailpreferences.updateEmailPreferences"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/conversions/v1beta/accounts/{accountsId}/conversionSources/{conversionSourcesId}","path_regex":"^(?:/conversions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.conversionSources.patch"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/datasources/v1beta/accounts/{accountsId}/dataSources/{dataSourcesId}","path_regex":"^(?:/datasources/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.dataSources.patch"},{"hostname":"merchantapi.googleapis.com","http_method":"PATCH","path_template":"/notifications/v1beta/accounts/{accountsId}/notificationsubscriptions/{notificationsubscriptionsId}","path_regex":"^(?:/notifications/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationsubscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.notificationsubscriptions.patch"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts/{accountsId}/homepage:claim","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/homepage:claim)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.homepage.claim"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts/{accountsId}/homepage:unclaim","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/homepage:unclaim)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.homepage.unclaim"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts/{accountsId}/programs/{programsId}:disable","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/programs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.programs.disable"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts/{accountsId}/programs/{programsId}:enable","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/programs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.programs.enable"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts/{accountsId}/regions","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.regions.create"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts/{accountsId}/shippingSettings:insert","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingSettings:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.shippingSettings.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts/{accountsId}/users","path_regex":"^(?:/accounts/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.users.create"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/accounts/v1beta/accounts:createAndConfigure","path_regex":"^(?:/accounts/v1beta/accounts:createAndConfigure)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.createAndConfigure"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/conversions/v1beta/accounts/{accountsId}/conversionSources","path_regex":"^(?:/conversions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionSources)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.conversionSources.create"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/conversions/v1beta/accounts/{accountsId}/conversionSources/{conversionSourcesId}:undelete","path_regex":"^(?:/conversions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.conversionSources.undelete"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/datasources/v1beta/accounts/{accountsId}/dataSources","path_regex":"^(?:/datasources/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.dataSources.create"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/datasources/v1beta/accounts/{accountsId}/dataSources/{dataSourcesId}:fetch","path_regex":"^(?:/datasources/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dataSources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetch)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.dataSources.fetch"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/inventories/v1beta/accounts/{accountsId}/products/{productsId}/localInventories:insert","path_regex":"^(?:/inventories/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/localInventories:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.localInventories.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/inventories/v1beta/accounts/{accountsId}/products/{productsId}/regionalInventories:insert","path_regex":"^(?:/inventories/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalInventories:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.products.regionalInventories.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/lfp/v1beta/accounts/{accountsId}/lfpInventories:insert","path_regex":"^(?:/lfp/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lfpInventories:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.lfpInventories.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/lfp/v1beta/accounts/{accountsId}/lfpSales:insert","path_regex":"^(?:/lfp/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lfpSales:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.lfpSales.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/lfp/v1beta/accounts/{accountsId}/lfpStores:insert","path_regex":"^(?:/lfp/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lfpStores:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.lfpStores.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/notifications/v1beta/accounts/{accountsId}/notificationsubscriptions","path_regex":"^(?:/notifications/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationsubscriptions)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.notificationsubscriptions.create"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/products/v1beta/accounts/{accountsId}/productInputs:insert","path_regex":"^(?:/products/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productInputs:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.productInputs.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/promotions/v1beta/accounts/{accountsId}/promotions:insert","path_regex":"^(?:/promotions/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions:insert)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.promotions.insert"},{"hostname":"merchantapi.googleapis.com","http_method":"POST","path_template":"/reports/v1beta/accounts/{accountsId}/reports:search","path_regex":"^(?:/reports/v1beta/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports:search)$","service_name":"google.merchantapi","resource_name":"merchantapi.accounts.reports.search"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions/{migrationExecutionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions/{migrationExecutionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.delete"},{"hostname":"metastore.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions/{migrationExecutionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.delete"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions/{migrationExecutionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions/{migrationExecutionsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.list"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/migrationExecutions/{migrationExecutionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migrationExecutions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.migrationExecutions.get"},{"hostname":"metastore.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.getIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.patch"},{"hostname":"metastore.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports/{metadataImportsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.patch"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.cancel"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterLocation","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterLocation)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterLocation"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterTableProperties","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterTableProperties)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterTableProperties"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:cancelMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.cancelMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:completeMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.completeMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:exportMetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.exportMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:moveTableToDatabase","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveTableToDatabase)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.moveTableToDatabase"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:queryMetadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.queryMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.restore"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:startMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.startMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.cancel"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/{servicesId1}:removeIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.removeIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterLocation","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterLocation)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterLocation"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterTableProperties","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterTableProperties)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterTableProperties"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:cancelMigration","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.cancelMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:completeMigration","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.completeMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:exportMetadata","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.exportMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:moveTableToDatabase","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveTableToDatabase)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.moveTableToDatabase"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:queryMetadata","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.queryMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:restore","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.restore"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:startMigration","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.startMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/federations/{federationsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/federations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.federations.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.operations.cancel"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.backups.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}/tables/{tablesId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.tables.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/databases/{databasesId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.databases.testIamPermissions"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/metadataImports","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadataImports)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.metadataImports.create"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/{servicesId1}:removeIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.removeIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterLocation","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterLocation)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterLocation"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:alterTableProperties","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::alterTableProperties)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.alterTableProperties"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:cancelMigration","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancelMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.cancelMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:completeMigration","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.completeMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:exportMetadata","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.exportMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:moveTableToDatabase","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::moveTableToDatabase)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.moveTableToDatabase"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:queryMetadata","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::queryMetadata)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.queryMetadata"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:restore","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::restore)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.restore"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.setIamPolicy"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:startMigration","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startMigration)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.startMigration"},{"hostname":"metastore.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.metastore","resource_name":"metastore.projects.locations.services.testIamPermissions"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles/{importDataFilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports/{reportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets/{assetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assetsExportJobs/{assetsExportJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assetsExportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assetsExportJobs.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles/{importDataFilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports/{reportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.delete"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveryClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles/{importDataFilesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/preferenceSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports/{reportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.getSettings"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/errorFrames","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorFrames)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.errorFrames.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/errorFrames/{errorFramesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorFrames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.errorFrames.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets/{assetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assetsExportJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assetsExportJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assetsExportJobs.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assetsExportJobs/{assetsExportJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assetsExportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assetsExportJobs.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/discoveryClients","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles/{importDataFilesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports/{reportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.getSettings"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/errorFrames","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorFrames)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.errorFrames.list"},{"hostname":"migrationcenter.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/errorFrames/{errorFramesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorFrames/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.errorFrames.get"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets/{assetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.updateSettings"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets/{assetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets/{preferenceSetsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/settings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.updateSettings"},{"hostname":"migrationcenter.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.patch"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets:aggregateValues","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:aggregateValues)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.aggregateValues"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets:batchDelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:batchDelete)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.batchDelete"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets:batchUpdate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:batchUpdate)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.batchUpdate"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/assets:reportAssetFrames","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:reportAssetFrames)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.reportAssetFrames"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveryClients","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}:sendHeartbeat","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sendHeartbeat)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.sendHeartbeat"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:addAssets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addAssets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.addAssets"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:removeAssets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeAssets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.removeAssets"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.run"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}:validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.validate"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.cancel"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/preferenceSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:aggregateValues","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:aggregateValues)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.aggregateValues"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:batchDelete","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:batchDelete)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.batchDelete"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:batchUpdate","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:batchUpdate)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.batchUpdate"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assets:reportAssetFrames","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:reportAssetFrames)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assets.reportAssetFrames"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assetsExportJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assetsExportJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assetsExportJobs.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/assetsExportJobs/{assetsExportJobsId}:run","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assetsExportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.assetsExportJobs.run"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/discoveryClients","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/discoveryClients/{discoveryClientsId}:sendHeartbeat","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/discoveryClients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sendHeartbeat)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.discoveryClients.sendHeartbeat"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:addAssets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addAssets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.addAssets"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:removeAssets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeAssets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.groups.removeAssets"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}/importDataFiles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importDataFiles)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.importDataFiles.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}:run","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.run"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/importJobs/{importJobsId}:validate","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/importJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.importJobs.validate"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.operations.cancel"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/preferenceSets","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferenceSets)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.preferenceSets.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/reportConfigs/{reportConfigsId}/reports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reportConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.reportConfigs.reports.create"},{"hostname":"migrationcenter.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.migrationcenter","resource_name":"migrationcenter.projects.locations.sources.create"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.delete"},{"hostname":"ml.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.operations.delete"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.ml","resource_name":"ml.projects.locations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.ml","resource_name":"ml.projects.locations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.operations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/models/{modelsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.getIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ml","resource_name":"ml.projects.operations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ml","resource_name":"ml.projects.operations.list"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.operations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.operations.get"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}:getConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getConfig)$","service_name":"google.ml","resource_name":"ml.projects.getConfig"},{"hostname":"ml.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}:getConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getConfig)$","service_name":"google.ml","resource_name":"ml.projects.getConfig"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.jobs.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.patch"},{"hostname":"ml.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ml","resource_name":"ml.projects.models.versions.patch"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.ml","resource_name":"ml.projects.jobs.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.jobs.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.jobs.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.jobs.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.jobs.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.jobs.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.locations.operations.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:addMeasurement","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addMeasurement)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.addMeasurement"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:checkEarlyStoppingState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkEarlyStoppingState)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.checkEarlyStoppingState"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:complete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.complete"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials/{trialsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.stop"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:listOptimalTrials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:listOptimalTrials)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.listOptimalTrials"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/studies/{studiesId}/trials:suggest","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/studies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trials:suggest)$","service_name":"google.ml","resource_name":"ml.projects.locations.studies.trials.suggest"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.ml","resource_name":"ml.projects.models.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.create"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}:setDefault","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefault)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.setDefault"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}/versions/{versionsId}:setDefault","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefault)$","service_name":"google.ml","resource_name":"ml.projects.models.versions.setDefault"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.ml","resource_name":"ml.projects.models.setIamPolicy"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.models.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/models/{modelsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.ml","resource_name":"ml.projects.models.testIamPermissions"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.operations.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ml","resource_name":"ml.projects.operations.cancel"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:explain","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::explain)$","service_name":"google.ml","resource_name":"ml.projects.explain"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:predict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.ml","resource_name":"ml.projects.predict"},{"hostname":"ml.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}:predict","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.ml","resource_name":"ml.projects.predict"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/global/metricsScopes/{metricsScopesId}/projects/{projectsId}","path_regex":"^(?:/v1/locations/global/metricsScopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.projects.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/dashboards/{dashboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/alertPolicies/{alertPoliciesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/metricDescriptors/{metricDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs/{uptimeCheckConfigsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.delete"},{"hostname":"monitoring.googleapis.com","http_method":"DELETE","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives/{serviceLevelObjectivesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.delete"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/locations/global/metricsScopes/{metricsScopesId}","path_regex":"^(?:/v1/locations/global/metricsScopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/locations/global/metricsScopes:listMetricsScopesByMonitoredProject","path_regex":"^(?:/v1/locations/global/metricsScopes:listMetricsScopesByMonitoredProject)$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.listMetricsScopesByMonitoredProject"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.operations.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dashboards","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards)$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/dashboards/{dashboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/label/{label}/values","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/label/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.label.values"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/metadata","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/metadata)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.metadata.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/folders/{foldersId}/timeSeries","path_regex":"^(?:/v3/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.folders.timeSeries.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/organizations/{organizationsId}/timeSeries","path_regex":"^(?:/v3/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.organizations.timeSeries.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/alertPolicies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies)$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/alertPolicies/{alertPoliciesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/groups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/groups/{groupsId}/members","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members)$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.members.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/metricDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/metricDescriptors/{metricDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/monitoredResourceDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoredResourceDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.monitoredResourceDescriptors.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/monitoredResourceDescriptors/{monitoredResourceDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/monitoredResourceDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.monitoredResourceDescriptors.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannelDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannelDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannelDescriptors.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannelDescriptors/{notificationChannelDescriptorsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannelDescriptors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannelDescriptors.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannels","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/snoozes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes)$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/snoozes/{snoozesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/timeSeries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs)$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs/{uptimeCheckConfigsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/uptimeCheckIps","path_regex":"^(?:/v3/uptimeCheckIps)$","service_name":"google.monitoring","resource_name":"monitoring.uptimeCheckIps.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.monitoring","resource_name":"monitoring.services.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.get"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives)$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.list"},{"hostname":"monitoring.googleapis.com","http_method":"GET","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives/{serviceLevelObjectivesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.get"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/dashboards/{dashboardsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/alertPolicies/{alertPoliciesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/snoozes/{snoozesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs/{uptimeCheckConfigsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.patch"},{"hostname":"monitoring.googleapis.com","http_method":"PATCH","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives/{serviceLevelObjectivesId}","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.patch"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/locations/global/metricsScopes/{metricsScopesId}/projects","path_regex":"^(?:/v1/locations/global/metricsScopes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.monitoring","resource_name":"monitoring.locations.global.metricsScopes.projects.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/dashboards","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dashboards)$","service_name":"google.monitoring","resource_name":"monitoring.projects.dashboards.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/labels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/labels)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.labels"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/query)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.query"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/query_exemplars","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/query_exemplars)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.query_exemplars"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/query_range","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/query_range)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.query_range"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/location/{location}/prometheus/api/v1/series","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/location/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/prometheus/api/v1/series)$","service_name":"google.monitoring","resource_name":"monitoring.projects.location.prometheus.api.v1.series"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/alertPolicies","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertPolicies)$","service_name":"google.monitoring","resource_name":"monitoring.projects.alertPolicies.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/collectdTimeSeries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectdTimeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.projects.collectdTimeSeries.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/groups","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/metricDescriptors","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metricDescriptors)$","service_name":"google.monitoring","resource_name":"monitoring.projects.metricDescriptors.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}:getVerificationCode","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getVerificationCode)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.getVerificationCode"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}:sendVerificationCode","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sendVerificationCode)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.sendVerificationCode"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/notificationChannels/{notificationChannelsId}:verify","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationChannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.monitoring","resource_name":"monitoring.projects.notificationChannels.verify"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/snoozes","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snoozes)$","service_name":"google.monitoring","resource_name":"monitoring.projects.snoozes.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/timeSeries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/timeSeries:createService","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries:createService)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.createService"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/timeSeries:query","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/timeSeries:query)$","service_name":"google.monitoring","resource_name":"monitoring.projects.timeSeries.query"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/uptimeCheckConfigs","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uptimeCheckConfigs)$","service_name":"google.monitoring","resource_name":"monitoring.projects.uptimeCheckConfigs.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/{v3Id}/{v3Id1}/services","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.monitoring","resource_name":"monitoring.services.create"},{"hostname":"monitoring.googleapis.com","http_method":"POST","path_template":"/v3/{v3Id}/{v3Id1}/services/{servicesId}/serviceLevelObjectives","path_regex":"^(?:/v3/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLevelObjectives)$","service_name":"google.monitoring","resource_name":"monitoring.services.serviceLevelObjectives.create"},{"hostname":"monitoring.googleapis.com","http_method":"PUT","path_template":"/v3/projects/{projectsId}/groups/{groupsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.monitoring","resource_name":"monitoring.projects.groups.update"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/accounts/{accountsId}/admins/{adminsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.delete"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/admins/{adminsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.delete"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts","path_regex":"^(?:/v1/accounts)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.get"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/admins","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/invitations","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.invitations.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/admins","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.list"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.patch"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/admins/{adminsId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.patch"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/admins/{adminsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.patch"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts","path_regex":"^(?:/v1/accounts)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.create"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/admins","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.admins.create"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/invitations/{invitationsId}:accept","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accept)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.invitations.accept"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/invitations/{invitationsId}:decline","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/invitations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decline)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.accounts.invitations.decline"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/admins","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/admins)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.admins.create"},{"hostname":"mybusinessaccountmanagement.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:transfer","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::transfer)$","service_name":"google.mybusinessaccountmanagement","resource_name":"mybusinessaccountmanagement.locations.transfer"},{"hostname":"mybusinessbusinesscalls.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/businesscallsinsights","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businesscallsinsights)$","service_name":"google.mybusinessbusinesscalls","resource_name":"mybusinessbusinesscalls.locations.businesscallsinsights.list"},{"hostname":"mybusinessbusinesscalls.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/businesscallssettings","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businesscallssettings)$","service_name":"google.mybusinessbusinesscalls","resource_name":"mybusinessbusinesscalls.locations.getBusinesscallssettings"},{"hostname":"mybusinessbusinesscalls.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/businesscallssettings","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/businesscallssettings)$","service_name":"google.mybusinessbusinesscalls","resource_name":"mybusinessbusinesscalls.locations.updateBusinesscallssettings"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.delete"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/locations","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.accounts.locations.list"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/attributes","path_regex":"^(?:/v1/attributes)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.attributes.list"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/categories","path_regex":"^(?:/v1/categories)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.categories.list"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/categories:batchGet","path_regex":"^(?:/v1/categories:batchGet)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.categories.batchGet"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/chains/{chainsId}","path_regex":"^(?:/v1/chains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.chains.get"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/chains:search","path_regex":"^(?:/v1/chains:search)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.chains.search"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.get"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/attributes","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.getAttributes"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/attributes:getGoogleUpdated","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes:getGoogleUpdated)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.attributes.getGoogleUpdated"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}:getGoogleUpdated","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getGoogleUpdated)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.getGoogleUpdated"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.patch"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/attributes","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributes)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.locations.updateAttributes"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"POST","path_template":"/v1/accounts/{accountsId}/locations","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.accounts.locations.create"},{"hostname":"mybusinessbusinessinformation.googleapis.com","http_method":"POST","path_template":"/v1/googleLocations:search","path_regex":"^(?:/v1/googleLocations:search)$","service_name":"google.mybusinessbusinessinformation","resource_name":"mybusinessbusinessinformation.googleLocations.search"},{"hostname":"mybusinesslodging.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/lodging","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lodging)$","service_name":"google.mybusinesslodging","resource_name":"mybusinesslodging.locations.getLodging"},{"hostname":"mybusinesslodging.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/lodging:getGoogleUpdated","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lodging:getGoogleUpdated)$","service_name":"google.mybusinesslodging","resource_name":"mybusinesslodging.locations.lodging.getGoogleUpdated"},{"hostname":"mybusinesslodging.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/lodging","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lodging)$","service_name":"google.mybusinesslodging","resource_name":"mybusinesslodging.locations.updateLodging"},{"hostname":"mybusinessnotifications.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountsId}/notificationSetting","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationSetting)$","service_name":"google.mybusinessnotifications","resource_name":"mybusinessnotifications.accounts.getNotificationSetting"},{"hostname":"mybusinessnotifications.googleapis.com","http_method":"PATCH","path_template":"/v1/accounts/{accountsId}/notificationSetting","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationSetting)$","service_name":"google.mybusinessnotifications","resource_name":"mybusinessnotifications.accounts.updateNotificationSetting"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/placeActionLinks/{placeActionLinksId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.delete"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/placeActionLinks","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks)$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.list"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/placeActionLinks/{placeActionLinksId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.get"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"GET","path_template":"/v1/placeActionTypeMetadata","path_regex":"^(?:/v1/placeActionTypeMetadata)$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.placeActionTypeMetadata.list"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/placeActionLinks/{placeActionLinksId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.patch"},{"hostname":"mybusinessplaceactions.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/placeActionLinks","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placeActionLinks)$","service_name":"google.mybusinessplaceactions","resource_name":"mybusinessplaceactions.locations.placeActionLinks.create"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/questions/{questionsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.delete"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"DELETE","path_template":"/v1/locations/{locationsId}/questions/{questionsId}/answers:delete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers:delete)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.answers.delete"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/questions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.list"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/questions/{questionsId}/answers","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.answers.list"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"PATCH","path_template":"/v1/locations/{locationsId}/questions/{questionsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.patch"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/questions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.create"},{"hostname":"mybusinessqanda.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/questions/{questionsId}/answers:upsert","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/questions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/answers:upsert)$","service_name":"google.mybusinessqanda","resource_name":"mybusinessqanda.locations.questions.answers.upsert"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/VoiceOfMerchantState","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/VoiceOfMerchantState)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.getVoiceOfMerchantState"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/verifications","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifications)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.verifications.list"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}/verifications/{verificationsId}:complete","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::complete)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.verifications.complete"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:fetchVerificationOptions","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchVerificationOptions)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.fetchVerificationOptions"},{"hostname":"mybusinessverifications.googleapis.com","http_method":"POST","path_template":"/v1/locations/{locationsId}:verify","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.mybusinessverifications","resource_name":"mybusinessverifications.locations.verify"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/regionalEndpoints/{regionalEndpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.regionalEndpoints.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionTokens/{serviceConnectionTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionTokens.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.delete"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.groups.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.groups.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/groups/{groupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.groups.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/routeTables","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routeTables)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.routeTables.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/routeTables/{routeTablesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routeTables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.routeTables.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/routeTables/{routeTablesId}/routes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routeTables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.routeTables.routes.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/routeTables/{routeTablesId}/routes/{routesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routeTables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.routeTables.routes.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:listSpokes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSpokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.listSpokes"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/regionalEndpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalEndpoints)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.regionalEndpoints.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/regionalEndpoints/{regionalEndpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.regionalEndpoints.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionTokens)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionTokens.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionTokens/{serviceConnectionTokensId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionTokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionTokens.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.list"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.get"},{"hostname":"networkconnectivity.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:getIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.getIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.groups.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.patch"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/groups/{groupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.groups.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}/groups/{groupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.groups.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:acceptSpoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acceptSpoke)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.acceptSpoke"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:rejectSpoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rejectSpoke)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.rejectSpoke"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/hubs/{hubsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/policyBasedRoutes/{policyBasedRoutesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/policyBasedRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.policyBasedRoutes.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.cancel"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/regionalEndpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalEndpoints)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.regionalEndpoints.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceClasses/{serviceClassesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceClasses.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionMaps/{serviceConnectionMapsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionMaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionMaps.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionPolicies/{serviceConnectionPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionPolicies.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceConnectionTokens","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceConnectionTokens)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.serviceConnectionTokens.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/global/hubs/{hubsId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/hubs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.global.hubs.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/internalRanges/{internalRangesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/internalRanges/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.internalRanges.testIamPermissions"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.operations.cancel"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.create"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:setIamPolicy","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.setIamPolicy"},{"hostname":"networkconnectivity.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/spokes/{spokesId}:testIamPermissions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spokes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkconnectivity","resource_name":"networkconnectivity.projects.locations.spokes.testIamPermissions"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.delete"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.getIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.getIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.list"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.get"},{"hostname":"networkmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.patch"},{"hostname":"networkmanagement.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.patch"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.create"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:rerun","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rerun)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.rerun"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.setIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.testIamPermissions"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.cancel"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.create"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:rerun","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rerun)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.rerun"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.setIamPolicy"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/connectivityTests/{connectivityTestsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/connectivityTests/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.connectivityTests.testIamPermissions"},{"hostname":"networkmanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/global/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkmanagement","resource_name":"networkmanagement.projects.locations.global.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints/{firewallEndpointsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups/{securityProfileGroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations/{firewallEndpointAssociationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints/{firewallEndpointsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups/{securityProfileGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations/{firewallEndpointAssociationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.delete"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:listReferences","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listReferences)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.listReferences"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints/{firewallEndpointsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups/{securityProfileGroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:listReferences","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listReferences)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.listReferences"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations/{firewallEndpointAssociationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:listReferences","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listReferences)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.listReferences"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints/{firewallEndpointsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups/{securityProfileGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:listReferences","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listReferences)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.listReferences"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations/{firewallEndpointAssociationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.getIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.get"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.list"},{"hostname":"networksecurity.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.get"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints/{firewallEndpointsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups/{securityProfileGroupsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations/{firewallEndpointAssociationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints/{firewallEndpointsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups/{securityProfileGroupsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles/{securityProfilesId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations/{firewallEndpointAssociationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules/{rulesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies/{tlsInspectionPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists/{urlListsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.patch"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:addItems","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.addItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:cloneItems","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cloneItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.cloneItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:removeItems","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.removeItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:addItems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.addItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:cloneItems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cloneItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.cloneItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:removeItems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.removeItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:addItems","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.addItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:cloneItems","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cloneItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.cloneItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:removeItems","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.addressGroups.removeItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/firewallEndpoints","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpoints)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.firewallEndpoints.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfileGroups","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfileGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfileGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/securityProfiles","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityProfiles)$","service_name":"google.networksecurity","resource_name":"networksecurity.organizations.locations.securityProfiles.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:addItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.addItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:cloneItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cloneItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.cloneItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:removeItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeItems)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.removeItems"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/addressGroups/{addressGroupsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addressGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.addressGroups.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authorizationPolicies/{authorizationPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizationPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authorizationPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzPolicies/{authzPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.authzPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clientTlsPolicies/{clientTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clientTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.clientTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/firewallEndpointAssociations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallEndpointAssociations)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.firewallEndpointAssociations.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gatewaySecurityPolicies/{gatewaySecurityPoliciesId}/rules","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gatewaySecurityPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.gatewaySecurityPolicies.rules.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.operations.cancel"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.setIamPolicy"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serverTlsPolicies/{serverTlsPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serverTlsPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.serverTlsPolicies.testIamPermissions"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsInspectionPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsInspectionPolicies)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.tlsInspectionPolicies.create"},{"hostname":"networksecurity.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/urlLists","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlLists)$","service_name":"google.networksecurity","resource_name":"networksecurity.projects.locations.urlLists.create"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions/{lbRouteExtensionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions/{lbTrafficExtensionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzExtensions/{authzExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.authzExtensions.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions/{lbRouteExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions/{lbTrafficExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.delete"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheKeysets/{edgeCacheKeysetsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheKeysets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheKeysets.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheOrigins/{edgeCacheOriginsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheOrigins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheOrigins.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheServices/{edgeCacheServicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheServices.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions/{lbRouteExtensionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions/{lbTrafficExtensionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzExtensions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.authzExtensions.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzExtensions/{authzExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.authzExtensions.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions/{lbRouteExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions/{lbTrafficExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings/{serviceBindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.getIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.list"},{"hostname":"networkservices.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.get"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions/{lbRouteExtensionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions/{lbTrafficExtensionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzExtensions/{authzExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.authzExtensions.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies/{endpointPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways/{gatewaysId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes/{grpcRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes/{httpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions/{lbRouteExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions/{lbTrafficExtensionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes/{meshesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes/{tcpRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes/{tlsRoutesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.patch"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheKeysets/{edgeCacheKeysetsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheKeysets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheKeysets.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheKeysets/{edgeCacheKeysetsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheKeysets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheKeysets.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheOrigins/{edgeCacheOriginsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheOrigins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheOrigins.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheOrigins/{edgeCacheOriginsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheOrigins/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheOrigins.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheServices/{edgeCacheServicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheServices.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/edgeCacheServices/{edgeCacheServicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/edgeCacheServices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.edgeCacheServices.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.cancel"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/authzExtensions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authzExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.authzExtensions.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/endpointPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpointPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.endpointPolicies.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/gateways","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gateways)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.gateways.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/grpcRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/grpcRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.grpcRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/httpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/httpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.httpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbRouteExtensions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbRouteExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbRouteExtensions.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/lbTrafficExtensions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lbTrafficExtensions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.lbTrafficExtensions.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/meshes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/meshes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.meshes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.operations.cancel"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceBindings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceBindings)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceBindings.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.setIamPolicy"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/serviceLbPolicies/{serviceLbPoliciesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceLbPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.serviceLbPolicies.testIamPermissions"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tcpRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tcpRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tcpRoutes.create"},{"hostname":"networkservices.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/tlsRoutes","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tlsRoutes)$","service_name":"google.networkservices","resource_name":"networkservices.projects.locations.tlsRoutes.create"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.delete"},{"hostname":"notebooks.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.delete"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments/{environmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.getIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getInstanceHealth","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getInstanceHealth)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.getInstanceHealth"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:isUpgradeable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::isUpgradeable)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.isUpgradeable"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.getIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.get"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:checkUpgradability","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::checkUpgradability)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.checkUpgradability"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.getIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances:getConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances:getConfig)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.getConfig"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.list"},{"hostname":"notebooks.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.get"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setAccelerator","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setAccelerator)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setAccelerator"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setLabels","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setLabels)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setLabels"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setMachineType","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMachineType)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setMachineType"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateConfig)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.updateConfig"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateMetadataItems","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateMetadataItems)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.updateMetadataItems"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:updateShieldedInstanceConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateShieldedInstanceConfig)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.updateShieldedInstanceConfig"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.patch"},{"hostname":"notebooks.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.patch"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/environments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.environments.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.executions.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:diagnose","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.diagnose"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:migrate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::migrate)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.migrate"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:report","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::report)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.report"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reportEvent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportEvent)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.reportEvent"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reset","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.reset"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.rollback"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.start"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.stop"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.testIamPermissions"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.upgrade"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgradeInternal","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgradeInternal)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.upgradeInternal"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances:register","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances:register)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.register"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.cancel"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:diagnose","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.diagnose"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:migrate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::migrate)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.migrate"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:refreshRuntimeTokenInternal","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::refreshRuntimeTokenInternal)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.refreshRuntimeTokenInternal"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:reportEvent","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportEvent)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.reportEvent"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:reset","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.reset"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.setIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.start"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.stop"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:switch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::switch)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.switch"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.testIamPermissions"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/runtimes/{runtimesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.runtimes.upgrade"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/schedules/{schedulesId}:trigger","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::trigger)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.schedules.trigger"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.create"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:diagnose","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::diagnose)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.diagnose"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reportInfoSystem","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reportInfoSystem)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.reportInfoSystem"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:reset","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.reset"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:resizeDisk","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resizeDisk)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.resizeDisk"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rollback","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.rollback"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.setIamPolicy"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:start","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.start"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:stop","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.stop"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.testIamPermissions"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.upgrade"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgradeSystem","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgradeSystem)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.instances.upgradeSystem"},{"hostname":"notebooks.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.notebooks","resource_name":"notebooks.projects.locations.operations.cancel"},{"hostname":"ondemandscanning.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.delete"},{"hostname":"ondemandscanning.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.delete"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.get"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scans/{scansId}/vulnerabilities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilities)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.vulnerabilities.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.get"},{"hostname":"ondemandscanning.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/scans/{scansId}/vulnerabilities","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilities)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.vulnerabilities.list"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.cancel"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.wait"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/scans:analyzePackages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans:analyzePackages)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.analyzePackages"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.cancel"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.operations.wait"},{"hostname":"ondemandscanning.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/scans:analyzePackages","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans:analyzePackages)$","service_name":"google.ondemandscanning","resource_name":"ondemandscanning.projects.locations.scans.analyzePackages"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/folders/{foldersId}/policies/{policiesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/customConstraints/{customConstraintsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/policies/{policiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.delete"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/constraints","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/constraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.constraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/policies","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/policies/{policiesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/folders/{foldersId}/policies/{policiesId}:getEffectivePolicy","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectivePolicy)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.getEffectivePolicy"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/constraints","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/constraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.constraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/customConstraints","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/customConstraints/{customConstraintsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/policies","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}:getEffectivePolicy","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectivePolicy)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.getEffectivePolicy"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/constraints","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/constraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.constraints.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/policies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.list"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/policies/{policiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.get"},{"hostname":"orgpolicy.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/policies/{policiesId}:getEffectivePolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getEffectivePolicy)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.getEffectivePolicy"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/folders/{foldersId}/policies/{policiesId}","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/customConstraints/{customConstraintsId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/organizations/{organizationsId}/policies/{policiesId}","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/policies/{policiesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.patch"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/folders/{foldersId}/policies","path_regex":"^(?:/v2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.folders.policies.create"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/customConstraints","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customConstraints)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.customConstraints.create"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/organizations/{organizationsId}/policies","path_regex":"^(?:/v2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.organizations.policies.create"},{"hostname":"orgpolicy.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/policies","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/policies)$","service_name":"google.orgpolicy","resource_name":"orgpolicy.projects.policies.create"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/guestPolicies/{guestPoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.delete"},{"hostname":"osconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.delete"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/global/projectFeatureSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/projectFeatureSettings)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.global.getProjectFeatureSettings"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventories","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventories)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventory","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/report","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/report)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/reports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReport","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReport)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.listRevisions"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchJobs/{patchJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/patchJobs/{patchJobsId}/instanceDetails","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceDetails)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.instanceDetails.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instanceOSPoliciesCompliances","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceOSPoliciesCompliances)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instanceOSPoliciesCompliances.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instanceOSPoliciesCompliances/{instanceOSPoliciesCompliancesId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceOSPoliciesCompliances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instanceOSPoliciesCompliances.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventories","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventories)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/inventory","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.inventories.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/report","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/report)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/osPolicyAssignments/{osPolicyAssignmentsId}/reports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.osPolicyAssignments.reports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReport","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReport)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/vulnerabilityReports","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vulnerabilityReports)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.instances.vulnerabilityReports.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}:listRevisions","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.listRevisions"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/guestPolicies","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies)$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/guestPolicies/{guestPoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchJobs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.list"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchJobs/{patchJobsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.get"},{"hostname":"osconfig.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/patchJobs/{patchJobsId}/instanceDetails","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceDetails)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.instanceDetails.list"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/global/projectFeatureSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/global/projectFeatureSettings)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.global.updateProjectFeatureSettings"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/guestPolicies/{guestPoliciesId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.patch"},{"hostname":"osconfig.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.patch"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:pause","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.pause"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.resume"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchJobs/{patchJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/patchJobs:execute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs:execute)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.execute"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/osPolicyAssignments/{osPolicyAssignmentsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/osPolicyAssignments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.locations.osPolicyAssignments.operations.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/guestPolicies","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/guestPolicies)$","service_name":"google.osconfig","resource_name":"osconfig.projects.guestPolicies.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchDeployments","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.create"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:pause","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.pause"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchDeployments/{patchDeploymentsId}:resume","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchDeployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchDeployments.resume"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchJobs/{patchJobsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.cancel"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/patchJobs:execute","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/patchJobs:execute)$","service_name":"google.osconfig","resource_name":"osconfig.projects.patchJobs.execute"},{"hostname":"osconfig.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/zones/{zonesId}/instances/{instancesId}:lookupEffectiveGuestPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::lookupEffectiveGuestPolicy)$","service_name":"google.osconfig","resource_name":"osconfig.projects.zones.instances.lookupEffectiveGuestPolicy"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1/users/{usersId}/projects/{projectsId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/users/{usersId}/projects/{projectsId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/users/{usersId}/projects/{projectsId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.delete"},{"hostname":"oslogin.googleapis.com","http_method":"DELETE","path_template":"/v1beta/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.delete"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/loginProfile","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loginProfile)$","service_name":"google.oslogin","resource_name":"oslogin.users.getLoginProfile"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.get"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1alpha/users/{usersId}/loginProfile","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loginProfile)$","service_name":"google.oslogin","resource_name":"oslogin.users.getLoginProfile"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1alpha/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.get"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1beta/users/{usersId}/loginProfile","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loginProfile)$","service_name":"google.oslogin","resource_name":"oslogin.users.getLoginProfile"},{"hostname":"oslogin.googleapis.com","http_method":"GET","path_template":"/v1beta/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.get"},{"hostname":"oslogin.googleapis.com","http_method":"PATCH","path_template":"/v1/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.patch"},{"hostname":"oslogin.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.patch"},{"hostname":"oslogin.googleapis.com","http_method":"PATCH","path_template":"/v1beta/users/{usersId}/sshPublicKeys/{sshPublicKeysId}","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.patch"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}/sshPublicKeys","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys)$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.create"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1/users/{usersId}:importSshPublicKey","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.importSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1alpha/users/{usersId}/projects/{projectsId}/locations/{locationsId}:signSshPublicKey","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.locations.signSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1alpha/users/{usersId}/projects/{projectsId}/zones/{zonesId}:signSshPublicKey","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.zones.signSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1alpha/users/{usersId}/sshPublicKeys","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys)$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.create"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1alpha/users/{usersId}:importSshPublicKey","path_regex":"^(?:/v1alpha/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.importSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1beta/users/{usersId}/projects/{projectsId}/locations/{locationsId}:signSshPublicKey","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.locations.signSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1beta/users/{usersId}/projects/{projectsId}/zones/{zonesId}:signSshPublicKey","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.projects.zones.signSshPublicKey"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1beta/users/{usersId}/sshPublicKeys","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sshPublicKeys)$","service_name":"google.oslogin","resource_name":"oslogin.users.sshPublicKeys.create"},{"hostname":"oslogin.googleapis.com","http_method":"POST","path_template":"/v1beta/users/{usersId}:importSshPublicKey","path_regex":"^(?:/v1beta/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importSshPublicKey)$","service_name":"google.oslogin","resource_name":"oslogin.users.importSshPublicKey"},{"hostname":"pagespeedonline.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v5/runPagespeed","path_regex":"^(?:/pagespeedonline/v5/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"partners.googleapis.com","http_method":"DELETE","path_template":"/v2/users/{userId}/companyRelation","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companyRelation)$","service_name":"google.partners","resource_name":"partners.users.deleteCompanyRelation"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/analytics","path_regex":"^(?:/v2/analytics)$","service_name":"google.partners","resource_name":"partners.analytics.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.partners","resource_name":"partners.companies.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/companies/{companyId}","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.partners","resource_name":"partners.companies.get"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/leads","path_regex":"^(?:/v2/leads)$","service_name":"google.partners","resource_name":"partners.leads.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/offers","path_regex":"^(?:/v2/offers)$","service_name":"google.partners","resource_name":"partners.offers.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/offers/history","path_regex":"^(?:/v2/offers/history)$","service_name":"google.partners","resource_name":"partners.offers.history.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/partnersstatus","path_regex":"^(?:/v2/partnersstatus)$","service_name":"google.partners","resource_name":"partners.getPartnersstatus"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/userStates","path_regex":"^(?:/v2/userStates)$","service_name":"google.partners","resource_name":"partners.userStates.list"},{"hostname":"partners.googleapis.com","http_method":"GET","path_template":"/v2/users/{userId}","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.partners","resource_name":"partners.users.get"},{"hostname":"partners.googleapis.com","http_method":"PATCH","path_template":"/v2/companies","path_regex":"^(?:/v2/companies)$","service_name":"google.partners","resource_name":"partners.updateCompanies"},{"hostname":"partners.googleapis.com","http_method":"PATCH","path_template":"/v2/leads","path_regex":"^(?:/v2/leads)$","service_name":"google.partners","resource_name":"partners.updateLeads"},{"hostname":"partners.googleapis.com","http_method":"PATCH","path_template":"/v2/users/profile","path_regex":"^(?:/v2/users/profile)$","service_name":"google.partners","resource_name":"partners.users.updateProfile"},{"hostname":"partners.googleapis.com","http_method":"POST","path_template":"/v2/clientMessages:log","path_regex":"^(?:/v2/clientMessages:log)$","service_name":"google.partners","resource_name":"partners.clientMessages.log"},{"hostname":"partners.googleapis.com","http_method":"POST","path_template":"/v2/companies/{companyId}/leads","path_regex":"^(?:/v2/companies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/leads)$","service_name":"google.partners","resource_name":"partners.companies.leads.create"},{"hostname":"partners.googleapis.com","http_method":"POST","path_template":"/v2/userEvents:log","path_regex":"^(?:/v2/userEvents:log)$","service_name":"google.partners","resource_name":"partners.userEvents.log"},{"hostname":"partners.googleapis.com","http_method":"PUT","path_template":"/v2/users/{userId}/companyRelation","path_regex":"^(?:/v2/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/companyRelation)$","service_name":"google.partners","resource_name":"partners.users.createCompanyRelation"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/products","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.products.list"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/promotions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.promotions.list"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"GET","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.get"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/promotions:findEligible","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions:findEligible)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.promotions.findEligible"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.create"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:cancel","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.cancel"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:entitle","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::entitle)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.entitle"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:extend","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::extend)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.extend"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions/{subscriptionsId}:undoCancel","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undoCancel)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.undoCancel"},{"hostname":"paymentsresellersubscription.googleapis.com","http_method":"POST","path_template":"/v1/partners/{partnersId}/subscriptions:provision","path_regex":"^(?:/v1/partners/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions:provision)$","service_name":"google.paymentsresellersubscription","resource_name":"paymentsresellersubscription.partners.subscriptions.provision"},{"hostname":"people.googleapis.com","http_method":"DELETE","path_template":"/v1/contactGroups/{contactGroupsId}","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.contactGroups.delete"},{"hostname":"people.googleapis.com","http_method":"DELETE","path_template":"/v1/people/{peopleId}:deleteContact","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteContact)$","service_name":"google.people","resource_name":"people.people.deleteContact"},{"hostname":"people.googleapis.com","http_method":"DELETE","path_template":"/v1/people/{peopleId}:deleteContactPhoto","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteContactPhoto)$","service_name":"google.people","resource_name":"people.people.deleteContactPhoto"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/contactGroups","path_regex":"^(?:/v1/contactGroups)$","service_name":"google.people","resource_name":"people.contactGroups.list"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/contactGroups/{contactGroupsId}","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.contactGroups.get"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/contactGroups:batchGet","path_regex":"^(?:/v1/contactGroups:batchGet)$","service_name":"google.people","resource_name":"people.contactGroups.batchGet"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/otherContacts","path_regex":"^(?:/v1/otherContacts)$","service_name":"google.people","resource_name":"people.otherContacts.list"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/otherContacts:search","path_regex":"^(?:/v1/otherContacts:search)$","service_name":"google.people","resource_name":"people.otherContacts.search"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people/{peopleId}","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.people.get"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people/{peopleId}/connections","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.people","resource_name":"people.people.connections.list"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:batchGet","path_regex":"^(?:/v1/people:batchGet)$","service_name":"google.people","resource_name":"people.people.getBatchGet"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:listDirectoryPeople","path_regex":"^(?:/v1/people:listDirectoryPeople)$","service_name":"google.people","resource_name":"people.people.listDirectoryPeople"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:searchContacts","path_regex":"^(?:/v1/people:searchContacts)$","service_name":"google.people","resource_name":"people.people.searchContacts"},{"hostname":"people.googleapis.com","http_method":"GET","path_template":"/v1/people:searchDirectoryPeople","path_regex":"^(?:/v1/people:searchDirectoryPeople)$","service_name":"google.people","resource_name":"people.people.searchDirectoryPeople"},{"hostname":"people.googleapis.com","http_method":"PATCH","path_template":"/v1/people/{peopleId}:updateContact","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateContact)$","service_name":"google.people","resource_name":"people.people.updateContact"},{"hostname":"people.googleapis.com","http_method":"PATCH","path_template":"/v1/people/{peopleId}:updateContactPhoto","path_regex":"^(?:/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateContactPhoto)$","service_name":"google.people","resource_name":"people.people.updateContactPhoto"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/contactGroups","path_regex":"^(?:/v1/contactGroups)$","service_name":"google.people","resource_name":"people.contactGroups.create"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/contactGroups/{contactGroupsId}/members:modify","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/members:modify)$","service_name":"google.people","resource_name":"people.contactGroups.members.modify"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/otherContacts/{otherContactsId}:copyOtherContactToMyContactsGroup","path_regex":"^(?:/v1/otherContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::copyOtherContactToMyContactsGroup)$","service_name":"google.people","resource_name":"people.otherContacts.copyOtherContactToMyContactsGroup"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:batchCreateContacts","path_regex":"^(?:/v1/people:batchCreateContacts)$","service_name":"google.people","resource_name":"people.people.batchCreateContacts"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:batchDeleteContacts","path_regex":"^(?:/v1/people:batchDeleteContacts)$","service_name":"google.people","resource_name":"people.people.batchDeleteContacts"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:batchUpdateContacts","path_regex":"^(?:/v1/people:batchUpdateContacts)$","service_name":"google.people","resource_name":"people.people.batchUpdateContacts"},{"hostname":"people.googleapis.com","http_method":"POST","path_template":"/v1/people:createContact","path_regex":"^(?:/v1/people:createContact)$","service_name":"google.people","resource_name":"people.people.createContact"},{"hostname":"people.googleapis.com","http_method":"PUT","path_template":"/v1/contactGroups/{contactGroupsId}","path_regex":"^(?:/v1/contactGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.people","resource_name":"people.contactGroups.update"},{"hostname":"places.googleapis.com","http_method":"GET","path_template":"/v1/places/{placesId}","path_regex":"^(?:/v1/places/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.places","resource_name":"places.places.get"},{"hostname":"places.googleapis.com","http_method":"GET","path_template":"/v1/places/{placesId}/photos/{photosId}/media","path_regex":"^(?:/v1/places/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/photos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/media)$","service_name":"google.places","resource_name":"places.places.photos.getMedia"},{"hostname":"places.googleapis.com","http_method":"POST","path_template":"/v1/places:autocomplete","path_regex":"^(?:/v1/places:autocomplete)$","service_name":"google.places","resource_name":"places.places.autocomplete"},{"hostname":"places.googleapis.com","http_method":"POST","path_template":"/v1/places:searchNearby","path_regex":"^(?:/v1/places:searchNearby)$","service_name":"google.places","resource_name":"places.places.searchNearby"},{"hostname":"places.googleapis.com","http_method":"POST","path_template":"/v1/places:searchText","path_regex":"^(?:/v1/places:searchText)$","service_name":"google.places","resource_name":"places.places.searchText"},{"hostname":"playablelocations.googleapis.com","http_method":"POST","path_template":"/v3:logImpressions","path_regex":"^(?:/v3:logImpressions)$","service_name":"google.playablelocations","resource_name":"playablelocations.logImpressions"},{"hostname":"playablelocations.googleapis.com","http_method":"POST","path_template":"/v3:logPlayerReports","path_regex":"^(?:/v3:logPlayerReports)$","service_name":"google.playablelocations","resource_name":"playablelocations.logPlayerReports"},{"hostname":"playablelocations.googleapis.com","http_method":"POST","path_template":"/v3:samplePlayableLocations","path_regex":"^(?:/v3:samplePlayableLocations)$","service_name":"google.playablelocations","resource_name":"playablelocations.samplePlayableLocations"},{"hostname":"playcustomapp.googleapis.com","http_method":"POST","path_template":"/playcustomapp/v1/accounts/{account}/customApps","path_regex":"^(?:/playcustomapp/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customApps)$","service_name":"google.playcustomapp","resource_name":"playcustomapp.accounts.customApps.create"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/anomalies","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anomalies)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.anomalies.list"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/anrRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/crashRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/errorCountMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/errorIssues:search","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorIssues:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.issues.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/errorReports:search","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorReports:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.reports.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/excessiveWakeupRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/slowRenderingRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/slowStartRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps/{appsId}:fetchReleaseFilterOptions","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchReleaseFilterOptions)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.apps.fetchReleaseFilterOptions"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1alpha1/apps:search","path_regex":"^(?:/v1alpha1/apps:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.apps.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/anomalies","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anomalies)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.anomalies.list"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/anrRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/crashRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/errorCountMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/errorIssues:search","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorIssues:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.issues.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/errorReports:search","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorReports:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.reports.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/excessiveWakeupRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/slowRenderingRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/slowStartRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.get"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps/{appsId}:fetchReleaseFilterOptions","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchReleaseFilterOptions)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.apps.fetchReleaseFilterOptions"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"GET","path_template":"/v1beta1/apps:search","path_regex":"^(?:/v1beta1/apps:search)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.apps.search"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/anrRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/crashRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/errorCountMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/excessiveWakeupRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/slowRenderingRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/slowStartRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet:query","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/anrRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anrRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.anrrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/crashRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crashRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.crashrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/errorCountMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/errorCountMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.errors.counts.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/excessiveWakeupRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/excessiveWakeupRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.excessivewakeuprate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/slowRenderingRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowRenderingRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowrenderingrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/slowStartRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/slowStartRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.slowstartrate.query"},{"hostname":"playdeveloperreporting.googleapis.com","http_method":"POST","path_template":"/v1beta1/apps/{appsId}/stuckBackgroundWakelockRateMetricSet:query","path_regex":"^(?:/v1beta1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stuckBackgroundWakelockRateMetricSet:query)$","service_name":"google.playdeveloperreporting","resource_name":"playdeveloperreporting.vitals.stuckbackgroundwakelockrate.query"},{"hostname":"playgrouping.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/tokens/{tokensId}/tags:createOrUpdate","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags:createOrUpdate)$","service_name":"google.playgrouping","resource_name":"playgrouping.apps.tokens.tags.createOrUpdate"},{"hostname":"playgrouping.googleapis.com","http_method":"POST","path_template":"/v1alpha1/apps/{appsId}/tokens/{tokensId}:verify","path_regex":"^(?:/v1alpha1/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::verify)$","service_name":"google.playgrouping","resource_name":"playgrouping.apps.tokens.verify"},{"hostname":"playintegrity.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/deviceRecall:write","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceRecall:write)$","service_name":"google.playintegrity","resource_name":"playintegrity.deviceRecall.write"},{"hostname":"playintegrity.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:decodeIntegrityToken","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decodeIntegrityToken)$","service_name":"google.playintegrity","resource_name":"playintegrity.decodeIntegrityToken"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/avails","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/avails)$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.avails.list"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/avails/{availId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/avails/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.avails.get"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/orders","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.orders.list"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/orders/{orderId}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.orders.get"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/storeInfos","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeInfos)$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.storeInfos.list"},{"hostname":"playmoviespartner.googleapis.com","http_method":"GET","path_template":"/v1/accounts/{accountId}/storeInfos/{videoId}/country/{country}","path_regex":"^(?:/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storeInfos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/country/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.playmoviespartner","resource_name":"playmoviespartner.accounts.storeInfos.country.get"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.folders.locations.activityTypes.activities.query"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.organizations.locations.activityTypes.activities.query"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.projects.locations.activityTypes.activities.query"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.folders.locations.activityTypes.activities.query"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.organizations.locations.activityTypes.activities.query"},{"hostname":"policyanalyzer.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/activityTypes/{activityTypesId}/activities:query","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activityTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities:query)$","service_name":"google.policyanalyzer","resource_name":"policyanalyzer.projects.locations.activityTypes.activities.query"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/operations","path_regex":"^(?:/v1alpha/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/operations/{operationsId}","path_regex":"^(?:/v1alpha/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/orgPolicyViolations","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.orgPolicyViolations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/operations","path_regex":"^(?:/v1beta/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/operations/{operationsId}","path_regex":"^(?:/v1beta/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/orgPolicyViolations","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.orgPolicyViolations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/results","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.results.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/orgPolicyViolationsPreviews/{orgPolicyViolationsPreviewsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.orgPolicyViolationsPreviews.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.list"},{"hostname":"policysimulator.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/replays/{replaysId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.operations.get"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/replays","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1alpha/folders/{foldersId}/locations/{locationsId}/replays","path_regex":"^(?:/v1alpha/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews:generate","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews:generate)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.generate"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1alpha/organizations/{organizationsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1alpha/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1beta/folders/{foldersId}/locations/{locationsId}/replays","path_regex":"^(?:/v1beta/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.folders.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/orgPolicyViolationsPreviews:generate","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orgPolicyViolationsPreviews:generate)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.orgPolicyViolationsPreviews.generate"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1beta/organizations/{organizationsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1beta/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.organizations.locations.replays.create"},{"hostname":"policysimulator.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/replays","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replays)$","service_name":"google.policysimulator","resource_name":"policysimulator.projects.locations.replays.create"},{"hostname":"policytroubleshooter.googleapis.com","http_method":"POST","path_template":"/v1/iam:troubleshoot","path_regex":"^(?:/v1/iam:troubleshoot)$","service_name":"google.policytroubleshooter","resource_name":"policytroubleshooter.iam.troubleshoot"},{"hostname":"policytroubleshooter.googleapis.com","http_method":"POST","path_template":"/v1beta/iam:troubleshoot","path_regex":"^(?:/v1beta/iam:troubleshoot)$","service_name":"google.policytroubleshooter","resource_name":"policytroubleshooter.iam.troubleshoot"},{"hostname":"pollen.googleapis.com","http_method":"GET","path_template":"/v1/forecast:lookup","path_regex":"^(?:/v1/forecast:lookup)$","service_name":"google.pollen","resource_name":"pollen.forecast.lookup"},{"hostname":"pollen.googleapis.com","http_method":"GET","path_template":"/v1/mapTypes/{mapType}/heatmapTiles/{zoom}/{x}/{y}","path_regex":"^(?:/v1/mapTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/heatmapTiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pollen","resource_name":"pollen.mapTypes.heatmapTiles.lookupHeatmapTile"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/assets","path_regex":"^(?:/v1/assets)$","service_name":"google.poly","resource_name":"poly.assets.list"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/assets/{assetsId}","path_regex":"^(?:/v1/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.poly","resource_name":"poly.assets.get"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/assets","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.poly","resource_name":"poly.users.assets.list"},{"hostname":"poly.googleapis.com","http_method":"GET","path_template":"/v1/users/{usersId}/likedassets","path_regex":"^(?:/v1/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/likedassets)$","service_name":"google.poly","resource_name":"poly.users.likedassets.list"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.delete"},{"hostname":"privateca.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.delete"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:fetch","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetch)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.fetch"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.certificateRevocationLists.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.list"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.get"},{"hostname":"privateca.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reusableConfigs/{reusableConfigsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reusableConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.reusableConfigs.getIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates/{certificatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.patch"},{"hostname":"privateca.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.patch"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.certificateRevocationLists.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:activate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.activate"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.disable"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.enable"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificateAuthorities/{certificateAuthoritiesId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificateAuthorities.undelete"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}/certificates/{certificatesId}:revoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revoke)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.certificates.revoke"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:fetchCaCerts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchCaCerts)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.fetchCaCerts"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/caPools/{caPoolsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/caPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.caPools.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.create"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/certificateTemplates/{certificateTemplatesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateTemplates.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.cancel"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.certificateRevocationLists.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}/certificateRevocationLists/{certificateRevocationListsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateRevocationLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.certificateRevocationLists.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/certificateAuthorities/{certificateAuthoritiesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthorities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.certificateAuthorities.testIamPermissions"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.operations.cancel"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reusableConfigs/{reusableConfigsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reusableConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.reusableConfigs.setIamPolicy"},{"hostname":"privateca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/reusableConfigs/{reusableConfigsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reusableConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.privateca","resource_name":"privateca.projects.locations.reusableConfigs.testIamPermissions"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.delete"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers","path_regex":"^(?:/v1alpha1/customers)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers:listGcpProjectDeployments","path_regex":"^(?:/v1alpha1/customers:listGcpProjectDeployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.listGcpProjectDeployments"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers:listLegacyOrganizations","path_regex":"^(?:/v1alpha1/customers:listLegacyOrganizations)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.listLegacyOrganizations"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.deployments.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.devices.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.nodes.list"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.updateSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.updateSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.updateSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.patch"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.deployments.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.signDevice"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.deployments.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.nodes.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:migrateOrganization","path_regex":"^(?:/v1alpha1/customers:migrateOrganization)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.migrateOrganization"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:provisionDeployment","path_regex":"^(?:/v1alpha1/customers:provisionDeployment)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.provisionDeployment"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:setupSasAnalytics","path_regex":"^(?:/v1alpha1/customers:setupSasAnalytics)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.customers.setupSasAnalytics"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.deployments.devices.signDevice"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:generateSecret","path_regex":"^(?:/v1alpha1/installer:generateSecret)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.installer.generateSecret"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:validate","path_regex":"^(?:/v1alpha1/installer:validate)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.installer.validate"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.deployments.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.signDevice"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.deployments.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.devices.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.devices.createSigned"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.nodes.create"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.nodes.nodes.move"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:get","path_regex":"^(?:/v1alpha1/policies:get)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.policies.get"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:set","path_regex":"^(?:/v1alpha1/policies:set)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.policies.set"},{"hostname":"prod-tt-sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:test","path_regex":"^(?:/v1alpha1/policies:test)$","service_name":"google.prod_tt_sasportal","resource_name":"prod_tt_sasportal.policies.test"},{"hostname":"proximitybeacon.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/beacons/{beaconsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.delete"},{"hostname":"proximitybeacon.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/beacons/{beaconsId}/attachments/{attachmentsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.delete"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons","path_regex":"^(?:/v1beta1/beacons)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons/{beaconsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.get"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons/{beaconsId}/attachments","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/beacons/{beaconsId}/diagnostics","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diagnostics)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.diagnostics.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/eidparams","path_regex":"^(?:/v1beta1/eidparams)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.getEidparams"},{"hostname":"proximitybeacon.googleapis.com","http_method":"GET","path_template":"/v1beta1/namespaces","path_regex":"^(?:/v1beta1/namespaces)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.namespaces.list"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beaconinfo:getforobserved","path_regex":"^(?:/v1beta1/beaconinfo:getforobserved)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beaconinfo.getforobserved"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}/attachments","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.create"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}/attachments:batchDelete","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments:batchDelete)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.attachments.batchDelete"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}:activate","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.activate"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}:deactivate","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deactivate)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.deactivate"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons/{beaconsId}:decommission","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::decommission)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.decommission"},{"hostname":"proximitybeacon.googleapis.com","http_method":"POST","path_template":"/v1beta1/beacons:register","path_regex":"^(?:/v1beta1/beacons:register)$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.register"},{"hostname":"proximitybeacon.googleapis.com","http_method":"PUT","path_template":"/v1beta1/beacons/{beaconsId}","path_regex":"^(?:/v1beta1/beacons/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.beacons.update"},{"hostname":"proximitybeacon.googleapis.com","http_method":"PUT","path_template":"/v1beta1/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.proximitybeacon","resource_name":"proximitybeacon.namespaces.update"},{"hostname":"publicca.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/externalAccountKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccountKeys)$","service_name":"google.publicca","resource_name":"publicca.projects.locations.externalAccountKeys.create"},{"hostname":"publicca.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/externalAccountKeys","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccountKeys)$","service_name":"google.publicca","resource_name":"publicca.projects.locations.externalAccountKeys.create"},{"hostname":"publicca.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/externalAccountKeys","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccountKeys)$","service_name":"google.publicca","resource_name":"publicca.projects.locations.externalAccountKeys.create"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:deleteRevision","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteRevision)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.deleteRevision"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1a/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta1a/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta1a/topics/{topicsId}","path_regex":"^(?:/v1beta1a/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.topics.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.delete"},{"hostname":"pubsub.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.delete"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.listRevisions"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/subscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}/snapshots","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.snapshots.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}/subscriptions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/subscriptions","path_regex":"^(?:/v1beta1a/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta1a/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/topics","path_regex":"^(?:/v1beta1a/topics)$","service_name":"google.pubsub","resource_name":"pubsub.topics.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta1a/topics/{topicsId}","path_regex":"^(?:/v1beta1a/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.topics.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/subscriptions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.get"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}/subscriptions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.subscriptions.list"},{"hostname":"pubsub.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.getIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.patch"},{"hostname":"pubsub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.patch"},{"hostname":"pubsub.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.patch"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.create"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.commit"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.rollback"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas/{schemasId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas:validate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas:validate)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.validate"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/schemas:validateMessage","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/schemas:validateMessage)$","service_name":"google.pubsub","resource_name":"pubsub.projects.schemas.validateMessage"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:acknowledge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.acknowledge"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:detach","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detach)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.detach"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyAckDeadline","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAckDeadline)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyAckDeadline"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyPushConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyPushConfig)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyPushConfig"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:pull","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pull)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.pull"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:seek","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::seek)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.seek"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:publish","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.publish"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/topics/{topicsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions","path_regex":"^(?:/v1beta1a/subscriptions)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.create"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/acknowledge","path_regex":"^(?:/v1beta1a/subscriptions/acknowledge)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.acknowledge"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/modifyAckDeadline","path_regex":"^(?:/v1beta1a/subscriptions/modifyAckDeadline)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.modifyAckDeadline"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/modifyPushConfig","path_regex":"^(?:/v1beta1a/subscriptions/modifyPushConfig)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.modifyPushConfig"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/pull","path_regex":"^(?:/v1beta1a/subscriptions/pull)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.pull"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/subscriptions/pullBatch","path_regex":"^(?:/v1beta1a/subscriptions/pullBatch)$","service_name":"google.pubsub","resource_name":"pubsub.subscriptions.pullBatch"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/topics","path_regex":"^(?:/v1beta1a/topics)$","service_name":"google.pubsub","resource_name":"pubsub.topics.create"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/topics/publish","path_regex":"^(?:/v1beta1a/topics/publish)$","service_name":"google.pubsub","resource_name":"pubsub.topics.publish"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta1a/topics/publishBatch","path_regex":"^(?:/v1beta1a/topics/publishBatch)$","service_name":"google.pubsub","resource_name":"pubsub.topics.publishBatch"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:acknowledge","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::acknowledge)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.acknowledge"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyAckDeadline","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyAckDeadline)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyAckDeadline"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:modifyPushConfig","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::modifyPushConfig)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.modifyPushConfig"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:pull","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pull)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.pull"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:publish","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.publish"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.setIamPolicy"},{"hostname":"pubsub.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.testIamPermissions"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/snapshots/{snapshotsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/snapshots/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.snapshots.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.subscriptions.create"},{"hostname":"pubsub.googleapis.com","http_method":"PUT","path_template":"/v1beta2/projects/{projectsId}/topics/{topicsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsub","resource_name":"pubsub.projects.topics.create"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"DELETE","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.delete"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}/topics","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.topics.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.get"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}/partitions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/partitions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.getPartitions"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}/subscriptions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.subscriptions.list"},{"hostname":"pubsublite.googleapis.com","http_method":"GET","path_template":"/v1/cursor/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}/cursors","path_regex":"^(?:/v1/cursor/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cursors)$","service_name":"google.pubsublite","resource_name":"pubsublite.cursor.projects.locations.subscriptions.cursors.list"},{"hostname":"pubsublite.googleapis.com","http_method":"PATCH","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations/{reservationsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.patch"},{"hostname":"pubsublite.googleapis.com","http_method":"PATCH","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.patch"},{"hostname":"pubsublite.googleapis.com","http_method":"PATCH","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.patch"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.operations.cancel"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.reservations.create"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.create"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:seek","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::seek)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.subscriptions.seek"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/admin/projects/{projectsId}/locations/{locationsId}/topics","path_regex":"^(?:/v1/admin/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics)$","service_name":"google.pubsublite","resource_name":"pubsublite.admin.projects.locations.topics.create"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/cursor/projects/{projectsId}/locations/{locationsId}/subscriptions/{subscriptionsId}:commitCursor","path_regex":"^(?:/v1/cursor/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commitCursor)$","service_name":"google.pubsublite","resource_name":"pubsublite.cursor.projects.locations.subscriptions.commitCursor"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/topicStats/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}:computeHeadCursor","path_regex":"^(?:/v1/topicStats/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeHeadCursor)$","service_name":"google.pubsublite","resource_name":"pubsublite.topicStats.projects.locations.topics.computeHeadCursor"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/topicStats/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}:computeMessageStats","path_regex":"^(?:/v1/topicStats/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeMessageStats)$","service_name":"google.pubsublite","resource_name":"pubsublite.topicStats.projects.locations.topics.computeMessageStats"},{"hostname":"pubsublite.googleapis.com","http_method":"POST","path_template":"/v1/topicStats/projects/{projectsId}/locations/{locationsId}/topics/{topicsId}:computeTimeCursor","path_regex":"^(?:/v1/topicStats/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/topics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::computeTimeCursor)$","service_name":"google.pubsublite","resource_name":"pubsublite.topicStats.projects.locations.topics.computeTimeCursor"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors/{collectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.delete"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.operations.delete"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.list"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.get"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/annotations/{annotationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.annotations.get"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.list"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors/{collectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.get"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.operations.list"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.operations.get"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors/{collectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.patch"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/annotations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/annotations)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.annotations.create"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.create"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors/{collectorsId}:pause","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.pause"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors/{collectorsId}:register","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::register)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.register"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/collectors/{collectorsId}:resume","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.collectors.resume"},{"hostname":"rapidmigrationassessment.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.rapidmigrationassessment","resource_name":"rapidmigrationassessment.projects.locations.operations.cancel"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"DELETE","path_template":"/v1/publications/{publicationsId}/readers/{readersId}","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.delete"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"GET","path_template":"/v1/publications/{publicationsId}/readers/{readersId}","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.get"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"GET","path_template":"/v1/publications/{publicationsId}/readers/{readersId}/entitlements","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.getEntitlements"},{"hostname":"readerrevenuesubscriptionlinking.googleapis.com","http_method":"PATCH","path_template":"/v1/publications/{publicationsId}/readers/{readersId}/entitlements","path_regex":"^(?:/v1/publications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/readers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entitlements)$","service_name":"google.readerrevenuesubscriptionlinking","resource_name":"readerrevenuesubscriptionlinking.publications.readers.updateEntitlements"},{"hostname":"realtimebidding.googleapis.com","http_method":"DELETE","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.delete"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders","path_regex":"^(?:/v1/bidders)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/creatives","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.creatives.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/endpoints","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.endpoints.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.endpoints.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/publisherConnections","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/bidders/{biddersId}/publisherConnections/{publisherConnectionsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers","path_regex":"^(?:/v1/buyers)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/creatives","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/creatives/{creativesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/userLists","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.get"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}:getRemarketingTag","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getRemarketingTag)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.getRemarketingTag"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1/buyers/{buyersId}:getRemarketingTag","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getRemarketingTag)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.getRemarketingTag"},{"hostname":"realtimebidding.googleapis.com","http_method":"GET","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.list"},{"hostname":"realtimebidding.googleapis.com","http_method":"PATCH","path_template":"/v1/bidders/{biddersId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.endpoints.patch"},{"hostname":"realtimebidding.googleapis.com","http_method":"PATCH","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.patch"},{"hostname":"realtimebidding.googleapis.com","http_method":"PATCH","path_template":"/v1/buyers/{buyersId}/creatives/{creativesId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.patch"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/creatives:watch","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives:watch)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.creatives.watch"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:activate","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.activate"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:addTargetedApps","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTargetedApps)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.addTargetedApps"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:addTargetedPublishers","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTargetedPublishers)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.addTargetedPublishers"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:addTargetedSites","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addTargetedSites)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.addTargetedSites"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:removeTargetedApps","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeTargetedApps)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.removeTargetedApps"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:removeTargetedPublishers","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeTargetedPublishers)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.removeTargetedPublishers"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:removeTargetedSites","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeTargetedSites)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.removeTargetedSites"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/pretargetingConfigs/{pretargetingConfigsId}:suspend","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pretargetingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::suspend)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.pretargetingConfigs.suspend"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/publisherConnections:batchApprove","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections:batchApprove)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.batchApprove"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/bidders/{biddersId}/publisherConnections:batchReject","path_regex":"^(?:/v1/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publisherConnections:batchReject)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.publisherConnections.batchReject"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/creatives","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.creatives.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/userLists","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}:close","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.close"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}:open","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::open)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.open"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.create"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions/{biddingFunctionsId}:activate","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::activate)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.activate"},{"hostname":"realtimebidding.googleapis.com","http_method":"POST","path_template":"/v1alpha/bidders/{biddersId}/biddingFunctions/{biddingFunctionsId}:archive","path_regex":"^(?:/v1alpha/bidders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/biddingFunctions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::archive)$","service_name":"google.realtimebidding","resource_name":"realtimebidding.bidders.biddingFunctions.archive"},{"hostname":"realtimebidding.googleapis.com","http_method":"PUT","path_template":"/v1/buyers/{buyersId}/userLists/{userListsId}","path_regex":"^(?:/v1/buyers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.realtimebidding","resource_name":"realtimebidding.buyers.userLists.update"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/firewallpolicies/{firewallpoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.delete"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.delete"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/firewallpolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/firewallpolicies/{firewallpoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.get"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.get"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys/{keysId}/metrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.getMetrics"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/keys/{keysId}:retrieveLegacySecretKey","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::retrieveLegacySecretKey)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.retrieveLegacySecretKey"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/relatedaccountgroups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/relatedaccountgroups)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.relatedaccountgroups.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/relatedaccountgroups/{relatedaccountgroupsId}/memberships","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/relatedaccountgroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/memberships)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.relatedaccountgroups.memberships.list"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/firewallpolicies/{firewallpoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.patch"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/keys/{keysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.patch"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/assessments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assessments)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.assessments.create"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/assessments/{assessmentsId}:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assessments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::annotate)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.assessments.annotate"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/firewallpolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.create"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/firewallpolicies:reorder","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/firewallpolicies:reorder)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.firewallpolicies.reorder"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/keys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.create"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/keys/{keysId}:addIpOverride","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addIpOverride)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.addIpOverride"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/keys/{keysId}:migrate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/keys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::migrate)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.keys.migrate"},{"hostname":"recaptchaenterprise.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/relatedaccountgroupmemberships:search","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/relatedaccountgroupmemberships:search)$","service_name":"google.recaptchaenterprise","resource_name":"recaptchaenterprise.projects.relatedaccountgroupmemberships.search"},{"hostname":"recommendationengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems/{catalogItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.delete"},{"hostname":"recommendationengine.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/predictionApiKeyRegistrations/{predictionApiKeyRegistrationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/predictionApiKeyRegistrations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.predictionApiKeyRegistrations.delete"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems/{catalogItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.get"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.operations.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.operations.get"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/predictionApiKeyRegistrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/predictionApiKeyRegistrations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.predictionApiKeyRegistrations.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:collect","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.collect"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.operations.list"},{"hostname":"recommendationengine.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.operations.get"},{"hostname":"recommendationengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.patch"},{"hostname":"recommendationengine.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems/{catalogItemsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.patch"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.create"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/catalogItems:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogItems:import)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.catalogItems.import"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/placements/{placementsId}:predict","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.placements.predict"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/predictionApiKeyRegistrations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/predictionApiKeyRegistrations)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.predictionApiKeyRegistrations.create"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.import"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:purge","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.purge"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:rejoin","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.rejoin"},{"hostname":"recommendationengine.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/eventStores/{eventStoresId}/userEvents:write","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventStores/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.recommendationengine","resource_name":"recommendationengine.projects.locations.catalogs.eventStores.userEvents.write"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/insightTypes","path_regex":"^(?:/v1beta1/insightTypes)$","service_name":"google.recommender","resource_name":"recommender.insightTypes.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.getConfig"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.list"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.get"},{"hostname":"recommender.googleapis.com","http_method":"GET","path_template":"/v1beta1/recommenders","path_regex":"^(?:/v1beta1/recommenders)$","service_name":"google.recommender","resource_name":"recommender.recommenders.list"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/config","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.updateConfig"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/billingAccounts/{billingAccountsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/billingAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.billingAccounts.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/folders/{foldersId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.folders.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.organizations.locations.recommenders.recommendations.markSucceeded"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/insightTypes/{insightTypesId}/insights/{insightsId}:markAccepted","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insightTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markAccepted)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.insightTypes.insights.markAccepted"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markClaimed","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markClaimed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markClaimed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markDismissed","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markDismissed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markDismissed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markFailed","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markFailed)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markFailed"},{"hostname":"recommender.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/recommenders/{recommendersId}/recommendations/{recommendationsId}:markSucceeded","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommenders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::markSucceeded)$","service_name":"google.recommender","resource_name":"recommender.projects.locations.recommenders.recommendations.markSucceeded"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.delete"},{"hostname":"redis.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.delete"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.redis","resource_name":"redis.projects.locations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/certificateAuthority","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthority)$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.getCertificateAuthority"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/authString","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authString)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.getAuthString"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.redis","resource_name":"redis.projects.locations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/certificateAuthority","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/certificateAuthority)$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.getCertificateAuthority"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.get"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}/authString","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authString)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.getAuthString"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.list"},{"hostname":"redis.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.get"},{"hostname":"redis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.patch"},{"hostname":"redis.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.patch"},{"hostname":"redis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.patch"},{"hostname":"redis.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.patch"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.create"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.create"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.export"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:failover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failover)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.failover"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.import"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.rescheduleMaintenance"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.upgrade"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.cancel"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/clusters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.redis","resource_name":"redis.projects.locations.clusters.create"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.create"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:export","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::export)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.export"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:failover","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::failover)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.failover"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:import","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::import)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.import"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:rescheduleMaintenance","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rescheduleMaintenance)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.rescheduleMaintenance"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/instances/{instancesId}:upgrade","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgrade)$","service_name":"google.redis","resource_name":"redis.projects.locations.instances.upgrade"},{"hostname":"redis.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.redis","resource_name":"redis.projects.locations.operations.cancel"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.delete"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.media.download"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.list"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.projects.operations.get"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/actionResults/{hash}/{sizeBytes}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actionResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.actionResults.get"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/blobs/{hash}/{sizeBytes}:getTree","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getTree)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.getTree"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"GET","path_template":"/v2/{v2Id}/capabilities","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/capabilities)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.getCapabilities"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.media.upload"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.cancel"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/operations/{operationsId}:waitExecution","path_regex":"^(?:/v2/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::waitExecution)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.operations.waitExecution"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/actions:execute","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actions:execute)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.actions.execute"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/blobs:batchRead","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs:batchRead)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.batchRead"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/blobs:batchUpdate","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs:batchUpdate)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.batchUpdate"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"POST","path_template":"/v2/{v2Id}/blobs:findMissing","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blobs:findMissing)$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.blobs.findMissing"},{"hostname":"remotebuildexecution.googleapis.com","http_method":"PUT","path_template":"/v2/{v2Id}/actionResults/{hash}/{sizeBytes}","path_regex":"^(?:/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/actionResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.remotebuildexecution","resource_name":"remotebuildexecution.actionResults.update"},{"hostname":"reseller.googleapis.com","http_method":"DELETE","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.subscriptions.delete"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/customers/{customerId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.customers.get"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.subscriptions.get"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/resellernotify/getwatchdetails","path_regex":"^(?:/apps/reseller/v1/resellernotify/getwatchdetails)$","service_name":"google.reseller","resource_name":"reseller.resellernotify.getwatchdetails"},{"hostname":"reseller.googleapis.com","http_method":"GET","path_template":"/apps/reseller/v1/subscriptions","path_regex":"^(?:/apps/reseller/v1/subscriptions)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.list"},{"hostname":"reseller.googleapis.com","http_method":"PATCH","path_template":"/apps/reseller/v1/customers/{customerId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.customers.patch"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers","path_regex":"^(?:/apps/reseller/v1/customers)$","service_name":"google.reseller","resource_name":"reseller.customers.insert"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.insert"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/activate","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activate)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.activate"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/changePlan","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changePlan)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.changePlan"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/changeRenewalSettings","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeRenewalSettings)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.changeRenewalSettings"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/changeSeats","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeSeats)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.changeSeats"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/startPaidService","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startPaidService)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.startPaidService"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/customers/{customerId}/subscriptions/{subscriptionId}/suspend","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/suspend)$","service_name":"google.reseller","resource_name":"reseller.subscriptions.suspend"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/resellernotify/register","path_regex":"^(?:/apps/reseller/v1/resellernotify/register)$","service_name":"google.reseller","resource_name":"reseller.resellernotify.register"},{"hostname":"reseller.googleapis.com","http_method":"POST","path_template":"/apps/reseller/v1/resellernotify/unregister","path_regex":"^(?:/apps/reseller/v1/resellernotify/unregister)$","service_name":"google.reseller","resource_name":"reseller.resellernotify.unregister"},{"hostname":"reseller.googleapis.com","http_method":"PUT","path_template":"/apps/reseller/v1/customers/{customerId}","path_regex":"^(?:/apps/reseller/v1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.reseller","resource_name":"reseller.customers.update"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/settings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.resourcesettings","resource_name":"resourcesettings.folders.settings.list"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/settings/{settingsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.folders.settings.get"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/settings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.resourcesettings","resource_name":"resourcesettings.organizations.settings.list"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/settings/{settingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.organizations.settings.get"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/settings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.resourcesettings","resource_name":"resourcesettings.projects.settings.list"},{"hostname":"resourcesettings.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/settings/{settingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.projects.settings.get"},{"hostname":"resourcesettings.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/settings/{settingsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.folders.settings.patch"},{"hostname":"resourcesettings.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/settings/{settingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.organizations.settings.patch"},{"hostname":"resourcesettings.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/settings/{settingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.resourcesettings","resource_name":"resourcesettings.projects.settings.patch"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/merchantCenterAccountLinks/{merchantCenterAccountLinksId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantCenterAccountLinks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.merchantCenterAccountLinks.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.delete"},{"hostname":"retail.googleapis.com","http_method":"DELETE","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.delete"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:collect","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.collect"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:completeQuery","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completeQuery"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:getDefaultBranch","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/alertConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertConfig)$","service_name":"google.retail","resource_name":"retail.projects.getAlertConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/places/{placesId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/places/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.places.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/merchantCenterAccountLinks","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantCenterAccountLinks)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.merchantCenterAccountLinks.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:collect","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.collect"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:completeQuery","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completeQuery"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:getDefaultBranch","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/loggingConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loggingConfig)$","service_name":"google.retail","resource_name":"retail.projects.getLoggingConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/operations","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}/retailProject","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/retailProject)$","service_name":"google.retail","resource_name":"retail.projects.getRetailProject"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2alpha/projects/{projectsId}:enrolledSolutions","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enrolledSolutions)$","service_name":"google.retail","resource_name":"retail.projects.listEnrolledSolutions"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/alertConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertConfig)$","service_name":"google.retail","resource_name":"retail.projects.getAlertConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:collect","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:collect)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.collect"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:completeQuery","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::completeQuery)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completeQuery"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:getDefaultBranch","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.getDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.operations.get"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.retail","resource_name":"retail.projects.operations.list"},{"hostname":"retail.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.operations.get"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/alertConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertConfig)$","service_name":"google.retail","resource_name":"retail.projects.updateAlertConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2alpha/projects/{projectsId}/loggingConfig","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loggingConfig)$","service_name":"google.retail","resource_name":"retail.projects.updateLoggingConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/alertConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alertConfig)$","service_name":"google.retail","resource_name":"retail.projects.updateAlertConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateAttributesConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionConfig","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionConfig)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.updateCompletionConfig"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls/{controlsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.patch"},{"hostname":"retail.googleapis.com","http_method":"PATCH","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.patch"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:addCatalogAttribute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:addCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.addCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:removeCatalogAttribute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:removeCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.removeCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:replaceCatalogAttribute","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:replaceCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.replaceCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addFulfillmentPlaces","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addLocalInventories","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeFulfillmentPlaces","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeLocalInventories","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:setInventory","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setInventory)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.setInventory"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:purge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionData:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionData:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completionData.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:pause","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.pause"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:resume","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.resume"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:tune","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.tune"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:predict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:addControl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.addControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:predict","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:removeControl","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.removeControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:import","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:purge","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:rejoin","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.rejoin"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:write","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.write"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:exportAnalyticsMetrics","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAnalyticsMetrics)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.exportAnalyticsMetrics"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:setDefaultBranch","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.setDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:addCatalogAttribute","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:addCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.addCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:batchRemoveCatalogAttributes","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:batchRemoveCatalogAttributes)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.batchRemoveCatalogAttributes"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:removeCatalogAttribute","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:removeCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.removeCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:replaceCatalogAttribute","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:replaceCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.replaceCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addFulfillmentPlaces","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addLocalInventories","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeFulfillmentPlaces","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeLocalInventories","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:setInventory","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setInventory)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.setInventory"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:export","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:export)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.export"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:import","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:purge","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionData:import","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionData:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completionData.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/merchantCenterAccountLinks","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantCenterAccountLinks)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.merchantCenterAccountLinks.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:pause","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.pause"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:resume","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.resume"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:tune","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.tune"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:predict","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:search","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:addControl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.addControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:predict","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:removeControl","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.removeControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:export","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:export)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.export"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:import","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:purge","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:rejoin","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.rejoin"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:write","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.write"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:exportAnalyticsMetrics","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAnalyticsMetrics)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.exportAnalyticsMetrics"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:setDefaultBranch","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.setDefaultBranch"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}/retailProject:acceptTerms","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/retailProject:acceptTerms)$","service_name":"google.retail","resource_name":"retail.projects.retailProject.acceptTerms"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2alpha/projects/{projectsId}:enrollSolution","path_regex":"^(?:/v2alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enrollSolution)$","service_name":"google.retail","resource_name":"retail.projects.enrollSolution"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:addCatalogAttribute","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:addCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.addCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:batchRemoveCatalogAttributes","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:batchRemoveCatalogAttributes)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.batchRemoveCatalogAttributes"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:removeCatalogAttribute","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:removeCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.removeCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/attributesConfig:replaceCatalogAttribute","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attributesConfig:replaceCatalogAttribute)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.attributesConfig.replaceCatalogAttribute"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addFulfillmentPlaces","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:addLocalInventories","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.addLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeFulfillmentPlaces","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeFulfillmentPlaces)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeFulfillmentPlaces"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:removeLocalInventories","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeLocalInventories)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.removeLocalInventories"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products/{productsId}:setInventory","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setInventory)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.setInventory"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:export","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:export)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.export"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:import","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/branches/{branchesId}/products:purge","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/branches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.branches.products.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/completionData:import","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/completionData:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.completionData.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/controls","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/controls)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.controls.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:pause","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.pause"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:resume","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.resume"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/models/{modelsId}:tune","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::tune)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.models.tune"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:predict","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/placements/{placementsId}:search","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.placements.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.create"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:addControl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.addControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:predict","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::predict)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.predict"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:removeControl","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeControl)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.removeControl"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/servingConfigs/{servingConfigsId}:search","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/servingConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.servingConfigs.search"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:export","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:export)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.export"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:import","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:import)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.import"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:purge","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:purge)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.purge"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:rejoin","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:rejoin)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.rejoin"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}/userEvents:write","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userEvents:write)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.userEvents.write"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:exportAnalyticsMetrics","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportAnalyticsMetrics)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.exportAnalyticsMetrics"},{"hostname":"retail.googleapis.com","http_method":"POST","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/catalogs/{catalogsId}:setDefaultBranch","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/catalogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setDefaultBranch)$","service_name":"google.retail","resource_name":"retail.projects.locations.catalogs.setDefaultBranch"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions/{executionsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.executions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/revisions/{revisionsId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.revisions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.services.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.operations.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.revisions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.operations.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.delete"},{"hostname":"run.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/revisions/{revisionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.revisions.delete"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/apiextensions.k8s.io/v1beta1/customresourcedefinitions","path_regex":"^(?:/apis/apiextensions\\.k8s\\.io/v1beta1/customresourcedefinitions)$","service_name":"google.run","resource_name":"run.customresourcedefinitions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/apiextensions.k8s.io/v1beta1/namespaces/{namespacesId}/customresourcedefinitions/{customresourcedefinitionsId}","path_regex":"^(?:/apis/apiextensions\\.k8s\\.io/v1beta1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customresourcedefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.customresourcedefinitions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/authorizeddomains","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizeddomains)$","service_name":"google.run","resource_name":"run.namespaces.authorizeddomains.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.run","resource_name":"run.namespaces.executions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions/{executionsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.executions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/tasks","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.run","resource_name":"run.namespaces.tasks.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/tasks/{tasksId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.tasks.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/configurations","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.run","resource_name":"run.namespaces.configurations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/configurations/{configurationsId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.configurations.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/revisions","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.run","resource_name":"run.namespaces.revisions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/revisions/{revisionsId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.revisions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/routes","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.run","resource_name":"run.namespaces.routes.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/routes/{routesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.routes.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.namespaces.services.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.services.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/authorizeddomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizeddomains)$","service_name":"google.run","resource_name":"run.projects.authorizeddomains.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.run","resource_name":"run.projects.locations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/authorizeddomains","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/authorizeddomains)$","service_name":"google.run","resource_name":"run.projects.locations.authorizeddomains.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/configurations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations)$","service_name":"google.run","resource_name":"run.projects.locations.configurations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/configurations/{configurationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.configurations.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings/{domainmappingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.run","resource_name":"run.projects.locations.operations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.operations.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/revisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.run","resource_name":"run.projects.locations.revisions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/revisions/{revisionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.revisions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/routes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes)$","service_name":"google.run","resource_name":"run.projects.locations.routes.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/routes/{routesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/routes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.routes.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customresourcedefinitions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customresourcedefinitions)$","service_name":"google.run","resource_name":"run.projects.locations.customresourcedefinitions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/customresourcedefinitions/{customresourcedefinitionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customresourcedefinitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.customresourcedefinitions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}/tasks","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.tasks.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}/tasks/{tasksId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.tasks.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}/{executionsId1}:exportStatus","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportStatus)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.exportStatus"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.run","resource_name":"run.projects.locations.operations.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.operations.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/revisions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.run","resource_name":"run.projects.locations.services.revisions.list"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/revisions/{revisionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.revisions.get"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}/revisions/{revisionsId}/{revisionsId1}:exportStatus","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportStatus)$","service_name":"google.run","resource_name":"run.projects.locations.services.revisions.exportStatus"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.getIamPolicy"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/{locationsId1}:exportImageMetadata","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportImageMetadata)$","service_name":"google.run","resource_name":"run.projects.locations.exportImageMetadata"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/{locationsId1}:exportMetadata","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportMetadata)$","service_name":"google.run","resource_name":"run.projects.locations.exportMetadata"},{"hostname":"run.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}:exportProjectMetadata","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportProjectMetadata)$","service_name":"google.run","resource_name":"run.projects.locations.exportProjectMetadata"},{"hostname":"run.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.jobs.patch"},{"hostname":"run.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.patch"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/domains.cloudrun.com/v1/namespaces/{namespacesId}/domainmappings","path_regex":"^(?:/apis/domains\\.cloudrun\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.namespaces.domainmappings.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/executions/{executionsId}:cancel","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.run","resource_name":"run.namespaces.executions.cancel"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}:run","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.run","resource_name":"run.namespaces.jobs.run"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/run.googleapis.com/v1alpha1/namespaces/{namespacesId}/jobs","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1alpha1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.namespaces.jobs.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.namespaces.services.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/domainmappings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/domainmappings)$","service_name":"google.run","resource_name":"run.projects.locations.domainmappings.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.run","resource_name":"run.projects.locations.operations.wait"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.services.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.executions.cancel"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:run","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.run"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.jobs.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.run","resource_name":"run.projects.locations.operations.wait"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.run","resource_name":"run.projects.locations.services.create"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.run","resource_name":"run.projects.locations.services.setIamPolicy"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.run","resource_name":"run.projects.locations.services.testIamPermissions"},{"hostname":"run.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/{locationsId1}:exportImage","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportImage)$","service_name":"google.run","resource_name":"run.projects.locations.exportImage"},{"hostname":"run.googleapis.com","http_method":"PUT","path_template":"/apis/run.googleapis.com/v1/namespaces/{namespacesId}/jobs/{jobsId}","path_regex":"^(?:/apis/run\\.googleapis\\.com/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.jobs.replaceJob"},{"hostname":"run.googleapis.com","http_method":"PUT","path_template":"/apis/serving.knative.dev/v1/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/apis/serving\\.knative\\.dev/v1/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.namespaces.services.replaceService"},{"hostname":"run.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.run","resource_name":"run.projects.locations.services.replaceService"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.operations.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters/{waitersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.delete"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.operations.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.operations.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.list"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters/{waitersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.get"},{"hostname":"runtimeconfig.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.getIamPolicy"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.operations.cancel"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.create"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/operations/{operationsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.operations.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.create"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}:watch","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::watch)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.watch"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.create"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/waiters/{waitersId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/waiters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.waiters.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.setIamPolicy"},{"hostname":"runtimeconfig.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.testIamPermissions"},{"hostname":"runtimeconfig.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.update"},{"hostname":"runtimeconfig.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/configs/{configsId}/variables/{variablesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.runtimeconfig","resource_name":"runtimeconfig.projects.configs.variables.update"},{"hostname":"safebrowsing.googleapis.com","http_method":"GET","path_template":"/v4/encodedFullHashes/{encodedRequest}","path_regex":"^(?:/v4/encodedFullHashes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.safebrowsing","resource_name":"safebrowsing.encodedFullHashes.get"},{"hostname":"safebrowsing.googleapis.com","http_method":"GET","path_template":"/v4/encodedUpdates/{encodedRequest}","path_regex":"^(?:/v4/encodedUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.safebrowsing","resource_name":"safebrowsing.encodedUpdates.get"},{"hostname":"safebrowsing.googleapis.com","http_method":"GET","path_template":"/v4/threatLists","path_regex":"^(?:/v4/threatLists)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatLists.list"},{"hostname":"safebrowsing.googleapis.com","http_method":"GET","path_template":"/v5/hashes:search","path_regex":"^(?:/v5/hashes:search)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.hashes.search"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/fullHashes:find","path_regex":"^(?:/v4/fullHashes:find)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.fullHashes.find"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/threatHits","path_regex":"^(?:/v4/threatHits)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatHits.create"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/threatListUpdates:fetch","path_regex":"^(?:/v4/threatListUpdates:fetch)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatListUpdates.fetch"},{"hostname":"safebrowsing.googleapis.com","http_method":"POST","path_template":"/v4/threatMatches:find","path_regex":"^(?:/v4/threatMatches:find)$","service_name":"google.safebrowsing","resource_name":"safebrowsing.threatMatches.find"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.delete"},{"hostname":"sasportal.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.delete"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers","path_regex":"^(?:/v1alpha1/customers)$","service_name":"google.sasportal","resource_name":"sasportal.customers.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers:listGcpProjectDeployments","path_regex":"^(?:/v1alpha1/customers:listGcpProjectDeployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.listGcpProjectDeployments"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/customers:listLegacyOrganizations","path_regex":"^(?:/v1alpha1/customers:listLegacyOrganizations)$","service_name":"google.sasportal","resource_name":"sasportal.customers.listLegacyOrganizations"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.get"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.deployments.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.devices.list"},{"hostname":"sasportal.googleapis.com","http_method":"GET","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.nodes.list"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.updateSigned"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.updateSigned"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.patch"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:updateSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.updateSigned"},{"hostname":"sasportal.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.patch"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.customers.deployments.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.signDevice"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/deployments","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.deployments.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers/{customersId}/nodes/{nodesId}:move","path_regex":"^(?:/v1alpha1/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.customers.nodes.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:migrateOrganization","path_regex":"^(?:/v1alpha1/customers:migrateOrganization)$","service_name":"google.sasportal","resource_name":"sasportal.customers.migrateOrganization"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:provisionDeployment","path_regex":"^(?:/v1alpha1/customers:provisionDeployment)$","service_name":"google.sasportal","resource_name":"sasportal.customers.provisionDeployment"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/customers:setupSasAnalytics","path_regex":"^(?:/v1alpha1/customers:setupSasAnalytics)$","service_name":"google.sasportal","resource_name":"sasportal.customers.setupSasAnalytics"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/deployments/{deploymentsId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.sasportal","resource_name":"sasportal.deployments.devices.signDevice"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:generateSecret","path_regex":"^(?:/v1alpha1/installer:generateSecret)$","service_name":"google.sasportal","resource_name":"sasportal.installer.generateSecret"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/installer:validate","path_regex":"^(?:/v1alpha1/installer:validate)$","service_name":"google.sasportal","resource_name":"sasportal.installer.validate"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/deployments/{deploymentsId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.deployments.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices/{devicesId}:signDevice","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::signDevice)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.signDevice"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/deployments","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.deployments.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.devices.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/devices:createSigned","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices:createSigned)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.devices.createSigned"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}/nodes","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.nodes.create"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/nodes/{nodesId}/nodes/{nodesId1}:move","path_regex":"^(?:/v1alpha1/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.sasportal","resource_name":"sasportal.nodes.nodes.move"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:get","path_regex":"^(?:/v1alpha1/policies:get)$","service_name":"google.sasportal","resource_name":"sasportal.policies.get"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:set","path_regex":"^(?:/v1alpha1/policies:set)$","service_name":"google.sasportal","resource_name":"sasportal.policies.set"},{"hostname":"sasportal.googleapis.com","http_method":"POST","path_template":"/v1alpha1/policies:test","path_regex":"^(?:/v1alpha1/policies:test)$","service_name":"google.sasportal","resource_name":"sasportal.policies.test"},{"hostname":"script.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{scriptId}/deployments/{deploymentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.deployments.delete"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/processes","path_regex":"^(?:/v1/processes)$","service_name":"google.script","resource_name":"script.processes.list"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/processes:listScriptProcesses","path_regex":"^(?:/v1/processes:listScriptProcesses)$","service_name":"google.script","resource_name":"script.processes.listScriptProcesses"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.get"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.script","resource_name":"script.projects.getContent"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.script","resource_name":"script.projects.deployments.list"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/deployments/{deploymentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.deployments.get"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/metrics","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metrics)$","service_name":"google.script","resource_name":"script.projects.getMetrics"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.script","resource_name":"script.projects.versions.list"},{"hostname":"script.googleapis.com","http_method":"GET","path_template":"/v1/projects/{scriptId}/versions/{versionNumber}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.versions.get"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/projects","path_regex":"^(?:/v1/projects)$","service_name":"google.script","resource_name":"script.projects.create"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/projects/{scriptId}/deployments","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments)$","service_name":"google.script","resource_name":"script.projects.deployments.create"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/projects/{scriptId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.script","resource_name":"script.projects.versions.create"},{"hostname":"script.googleapis.com","http_method":"POST","path_template":"/v1/scripts/{scriptId}:run","path_regex":"^(?:/v1/scripts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.script","resource_name":"script.scripts.run"},{"hostname":"script.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{scriptId}/content","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/content)$","service_name":"google.script","resource_name":"script.projects.updateContent"},{"hostname":"script.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{scriptId}/deployments/{deploymentId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deployments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.script","resource_name":"script.projects.deployments.update"},{"hostname":"searchads360.googleapis.com","http_method":"GET","path_template":"/v0/customers/{customersId}/customColumns","path_regex":"^(?:/v0/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customColumns)$","service_name":"google.searchads360","resource_name":"searchads360.customers.customColumns.list"},{"hostname":"searchads360.googleapis.com","http_method":"GET","path_template":"/v0/customers/{customersId}/customColumns/{customColumnsId}","path_regex":"^(?:/v0/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customColumns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchads360","resource_name":"searchads360.customers.customColumns.get"},{"hostname":"searchads360.googleapis.com","http_method":"GET","path_template":"/v0/customers:listAccessibleCustomers","path_regex":"^(?:/v0/customers:listAccessibleCustomers)$","service_name":"google.searchads360","resource_name":"searchads360.customers.listAccessibleCustomers"},{"hostname":"searchads360.googleapis.com","http_method":"GET","path_template":"/v0/searchAds360Fields/{searchAds360FieldsId}","path_regex":"^(?:/v0/searchAds360Fields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchads360","resource_name":"searchads360.searchAds360Fields.get"},{"hostname":"searchads360.googleapis.com","http_method":"POST","path_template":"/v0/customers/{customersId}/searchAds360:search","path_regex":"^(?:/v0/customers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAds360:search)$","service_name":"google.searchads360","resource_name":"searchads360.customers.searchAds360.search"},{"hostname":"searchads360.googleapis.com","http_method":"POST","path_template":"/v0/searchAds360Fields:search","path_regex":"^(?:/v0/searchAds360Fields:search)$","service_name":"google.searchads360","resource_name":"searchads360.searchAds360Fields.search"},{"hostname":"searchconsole.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sites.delete"},{"hostname":"searchconsole.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.delete"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites","path_regex":"^(?:/webmasters/v3/sites)$","service_name":"google.searchconsole","resource_name":"webmasters.sites.list"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sites.get"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps)$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.list"},{"hostname":"searchconsole.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.get"},{"hostname":"searchconsole.googleapis.com","http_method":"POST","path_template":"/v1/urlInspection/index:inspect","path_regex":"^(?:/v1/urlInspection/index:inspect)$","service_name":"google.searchconsole","resource_name":"searchconsole.urlInspection.index.inspect"},{"hostname":"searchconsole.googleapis.com","http_method":"POST","path_template":"/v1/urlTestingTools/mobileFriendlyTest:run","path_regex":"^(?:/v1/urlTestingTools/mobileFriendlyTest:run)$","service_name":"google.searchconsole","resource_name":"searchconsole.urlTestingTools.mobileFriendlyTest.run"},{"hostname":"searchconsole.googleapis.com","http_method":"POST","path_template":"/webmasters/v3/sites/{siteUrl}/searchAnalytics/query","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAnalytics/query)$","service_name":"google.searchconsole","resource_name":"webmasters.searchanalytics.query"},{"hostname":"searchconsole.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sites.add"},{"hostname":"searchconsole.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.searchconsole","resource_name":"webmasters.sitemaps.submit"},{"hostname":"secretmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.delete"},{"hostname":"secretmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.delete"},{"hostname":"secretmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.delete"},{"hostname":"secretmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.delete"},{"hostname":"secretmanager.googleapis.com","http_method":"DELETE","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.delete"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:access","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::access)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.access"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.getIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:access","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::access)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.access"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.getIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:access","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::access)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.access"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.getIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:access","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::access)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.access"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.getIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/secrets","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}/versions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.list"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.get"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:access","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::access)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.access"},{"hostname":"secretmanager.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}:getIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.getIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.patch"},{"hostname":"secretmanager.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.patch"},{"hostname":"secretmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.patch"},{"hostname":"secretmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.patch"},{"hostname":"secretmanager.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.patch"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.create"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:destroy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.destroy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.disable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.enable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:addVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addVersion)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.addVersion"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.setIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.testIamPermissions"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.create"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:destroy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.destroy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.disable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.enable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:addVersion","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addVersion)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.addVersion"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.setIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/secrets/{secretsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.testIamPermissions"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.create"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:destroy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.destroy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:disable","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.disable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:enable","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.enable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:addVersion","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addVersion)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.addVersion"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.setIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/secrets/{secretsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.testIamPermissions"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.create"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:destroy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.destroy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:disable","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.disable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}/versions/{versionsId}:enable","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.versions.enable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:addVersion","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addVersion)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.addVersion"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.setIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/secrets/{secretsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.locations.secrets.testIamPermissions"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/secrets","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.create"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:destroy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::destroy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.destroy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:disable","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.disable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}/versions/{versionsId}:enable","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.versions.enable"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}:addVersion","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addVersion)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.addVersion"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}:setIamPolicy","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.setIamPolicy"},{"hostname":"secretmanager.googleapis.com","http_method":"POST","path_template":"/v1beta2/projects/{projectsId}/secrets/{secretsId}:testIamPermissions","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/secrets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.secretmanager","resource_name":"secretmanager.projects.secrets.testIamPermissions"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.locations.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.locations.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/resourceValueConfigs/{resourceValueConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceValueConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.resourceValueConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.delete"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/assets","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/bigQueryExports","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/customModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/customModules:listDescendant","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/effectiveCustomModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/muteConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.locations.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.locations.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/muteConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/notificationConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules:listDescendant","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/effectiveCustomModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/sources","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/assets","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/bigQueryExports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/customModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/customModules:listDescendant","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/effectiveCustomModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/muteConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.locations.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.locations.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/muteConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/resourceValueConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceValueConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.resourceValueConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/resourceValueConfigs/{resourceValueConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceValueConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.resourceValueConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules:listDescendant","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/effectiveCustomModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/simulations/{simulationsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.simulations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/simulations/{simulationsId}/attackExposureResults/{attackExposureResultsId}/attackPaths","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attackExposureResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attackPaths)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.simulations.attackExposureResults.attackPaths.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/simulations/{simulationsId}/attackExposureResults/{attackExposureResultsId}/valuedResources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attackExposureResults/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/valuedResources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.simulations.attackExposureResults.valuedResources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/simulations/{simulationsId}/attackPaths","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attackPaths)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.simulations.attackPaths.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/simulations/{simulationsId}/valuedResources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/valuedResources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.simulations.valuedResources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/simulations/{simulationsId}/valuedResources/{valuedResourcesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/valuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.simulations.valuedResources.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/simulations/{simulationsId}/valuedResources/{valuedResourcesId}/attackPaths","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/simulations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/valuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attackPaths)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.simulations.valuedResources.attackPaths.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/assets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/bigQueryExports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/customModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/customModules:listDescendant","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/effectiveCustomModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/muteConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/muteConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notificationConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules:listDescendant","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:listDescendant)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.listDescendant"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/effectiveCustomModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.effectiveCustomModules.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/effectiveCustomModules/{effectiveCustomModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/effectiveCustomModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.effectiveCustomModules.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/assets","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/eventThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/rapidVulnerabilityDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.rapidVulnerabilityDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/securityCenterSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityCenterSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getSecurityCenterSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/securityHealthAnalyticsSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/virtualMachineThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.virtualMachineThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.getWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/folders/{foldersId}/webSecurityScannerSettings:calculate","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.webSecurityScannerSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/eventThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/rapidVulnerabilityDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.rapidVulnerabilityDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/securityCenterSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityCenterSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getSecurityCenterSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/securityHealthAnalyticsSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/subscription","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subscription)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getSubscription"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/virtualMachineThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.virtualMachineThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/organizations/{organizationsId}/webSecurityScannerSettings:calculate","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.webSecurityScannerSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/eventThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.clusters.getContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/containerThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.clusters.containerThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/rapidVulnerabilityDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.rapidVulnerabilityDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/securityCenterSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityCenterSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getSecurityCenterSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/securityHealthAnalyticsSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/virtualMachineThreatDetectionSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.virtualMachineThreatDetectionSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.getWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1beta2/projects/{projectsId}/webSecurityScannerSettings:calculate","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings:calculate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.webSecurityScannerSettings.calculate"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/assets","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/operations","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/operations/{operationsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.getOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.list"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.get"},{"hostname":"securitycenter.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.list"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.locations.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}/externalSystems/{externalSystemsId}","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.externalSystems.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.locations.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/resourceValueConfigs/{resourceValueConfigsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceValueConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.resourceValueConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/externalSystems/{externalSystemsId}","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.externalSystems.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/bigQueryExports/{bigQueryExportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/muteConfigs/{muteConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules/{customModulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}/externalSystems/{externalSystemsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.externalSystems.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/folders/{foldersId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.updateWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/organizations/{organizationsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/eventThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateEventThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/locations/{locationsId}/clusters/{clustersId}/containerThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containerThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.clusters.updateContainerThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/rapidVulnerabilityDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rapidVulnerabilityDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateRapidVulnerabilityDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/securityHealthAnalyticsSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateSecurityHealthAnalyticsSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/virtualMachineThreatDetectionSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/virtualMachineThreatDetectionSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateVirtualMachineThreatDetectionSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1beta2/projects/{projectsId}/webSecurityScannerSettings","path_regex":"^(?:/v1beta2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webSecurityScannerSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.updateWebSecurityScannerSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/assets/{assetsId}/securityMarks","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs/{notificationConfigsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/organizationSettings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/organizationSettings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.updateOrganizationSettings"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.patch"},{"hostname":"securitycenter.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}/securityMarks","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityMarks)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.updateSecurityMarks"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/assets:group","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/bigQueryExports","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.bigQueryExports.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings/customModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/eventThreatDetectionSettings:validateCustomModule","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:validateCustomModule)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.eventThreatDetectionSettings.validateCustomModule"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/findings:bulkMute","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:bulkMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.findings.bulkMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/locations/{locationsId}/muteConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.locations.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/muteConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/notificationConfigs","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/securityHealthAnalyticsSettings/customModules:simulate","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:simulate)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.securityHealthAnalyticsSettings.customModules.simulate"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}:setMute","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.setMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/folders/{foldersId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.folders.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/assets:group","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/assets:runDiscovery","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:runDiscovery)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.runDiscovery"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/bigQueryExports","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.bigQueryExports.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings/customModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/eventThreatDetectionSettings:validateCustomModule","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:validateCustomModule)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.eventThreatDetectionSettings.validateCustomModule"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/findings:bulkMute","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:bulkMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.findings.bulkMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/locations/{locationsId}/muteConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.locations.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/muteConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/resourceValueConfigs:batchCreate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resourceValueConfigs:batchCreate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.resourceValueConfigs.batchCreate"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/securityHealthAnalyticsSettings/customModules:simulate","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:simulate)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.securityHealthAnalyticsSettings.customModules.simulate"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setMute","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}:getIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.getIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}:setIamPolicy","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.setIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/organizations/{organizationsId}/sources/{sourcesId}:testIamPermissions","path_regex":"^(?:/v1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.testIamPermissions"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/assets:group","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/bigQueryExports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bigQueryExports)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.bigQueryExports.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings/customModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/eventThreatDetectionSettings:validateCustomModule","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventThreatDetectionSettings:validateCustomModule)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.eventThreatDetectionSettings.validateCustomModule"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/findings:bulkMute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:bulkMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.findings.bulkMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/muteConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.locations.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/muteConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/muteConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.muteConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/notificationConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/securityHealthAnalyticsSettings/customModules:simulate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/securityHealthAnalyticsSettings/customModules:simulate)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.securityHealthAnalyticsSettings.customModules.simulate"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}:setMute","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setMute)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.setMute"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.projects.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/assets:group","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/assets:runDiscovery","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:runDiscovery)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.runDiscovery"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}:getIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.getIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}:setIamPolicy","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.setIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1beta1/organizations/{organizationsId}/sources/{sourcesId}:testIamPermissions","path_regex":"^(?:/v1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.testIamPermissions"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1alpha1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1p1alpha1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/assets:group","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/assets:runDiscovery","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/assets:runDiscovery)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.assets.runDiscovery"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/notificationConfigs","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.notificationConfigs.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.operations.cancel"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.create"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings/{findingsId}:setState","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setState)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.setState"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}/findings:group","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings:group)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.findings.group"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}:getIamPolicy","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.getIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}:setIamPolicy","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.setIamPolicy"},{"hostname":"securitycenter.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/organizations/{organizationsId}/sources/{sourcesId}:testIamPermissions","path_regex":"^(?:/v1p1beta1/organizations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.securitycenter","resource_name":"securitycenter.organizations.sources.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{instanceId}/service_bindings/{bindingId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.delete"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}:getIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.getIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/service_bindings","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.service_bindings.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/service_instances","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_instances)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.service_instances.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/catalog","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/catalog)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.catalog.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/last_operation","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}/last_operation","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1alpha1/{v1alpha1Id}:getIamPolicy","path_regex":"^(?:/v1alpha1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.getIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/bindings","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.bindings.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/bindings/{bindingsId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.bindings.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/instances/{instancesId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.instances.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/catalog","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/catalog)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.catalog.list"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.get"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}/last_operation","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/last_operation)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.getLast_operation"},{"hostname":"servicebroker.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}:getIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.getIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.patch"},{"hostname":"servicebroker.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.patch"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:setIamPolicy","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.setIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}:testIamPermissions","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicebroker","resource_name":"servicebroker.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1alpha1/{v1alpha1Id}:setIamPolicy","path_regex":"^(?:/v1alpha1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.setIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1alpha1/{v1alpha1Id}:testIamPermissions","path_regex":"^(?:/v1alpha1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicebroker","resource_name":"servicebroker.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/brokers","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers)$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.create"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:setIamPolicy","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicebroker","resource_name":"servicebroker.setIamPolicy"},{"hostname":"servicebroker.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}:testIamPermissions","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicebroker","resource_name":"servicebroker.testIamPermissions"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.create"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1alpha1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.create"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.create"},{"hostname":"servicebroker.googleapis.com","http_method":"PUT","path_template":"/v1beta1/projects/{projectsId}/brokers/{brokersId}/v2/service_instances/{service_instancesId}/service_bindings/{service_bindingsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/brokers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/v2/service_instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/service_bindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicebroker","resource_name":"servicebroker.projects.brokers.v2.service_instances.service_bindings.create"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.delete"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.delete"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides/{producerOverridesId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.delete"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerQuotaPolicies/{producerQuotaPoliciesId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerQuotaPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerQuotaPolicies.delete"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}:search","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::search)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.search"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.get"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"GET","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerQuotaPolicies","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerQuotaPolicies)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerQuotaPolicies.list"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides/{producerOverridesId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.patch"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerQuotaPolicies/{producerQuotaPoliciesId}","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerQuotaPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerQuotaPolicies.patch"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.operations.cancel"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.create"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:addProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.addProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:applyProjectConfig","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::applyProjectConfig)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.applyProjectConfig"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:attachProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::attachProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.attachProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:deleteProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::deleteProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.deleteProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:removeProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.removeProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}/tenancyUnits/{tenancyUnitsId}:undeleteProject","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tenancyUnits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undeleteProject)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.tenancyUnits.undeleteProject"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerOverrides","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerOverrides)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerOverrides.create"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/producerQuotaPolicies","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/producerQuotaPolicies)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.limits.producerQuotaPolicies.create"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics:importProducerOverrides","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics:importProducerOverrides)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.importProducerOverrides"},{"hostname":"serviceconsumermanagement.googleapis.com","http_method":"POST","path_template":"/v1beta1/services/{servicesId}/{servicesId1}/{servicesId2}/consumerQuotaMetrics:importProducerQuotaPolicies","path_regex":"^(?:/v1beta1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics:importProducerQuotaPolicies)$","service_name":"google.serviceconsumermanagement","resource_name":"serviceconsumermanagement.services.consumerQuotaMetrics.importProducerQuotaPolicies"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:allocateQuota","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::allocateQuota)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.allocateQuota"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:check","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::check)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.check"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:report","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::report)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.report"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v2/services/{serviceName}:check","path_regex":"^(?:/v2/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::check)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.check"},{"hostname":"servicecontrol.googleapis.com","http_method":"POST","path_template":"/v2/services/{serviceName}:report","path_regex":"^(?:/v2/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::report)$","service_name":"google.servicecontrol","resource_name":"servicecontrol.services.report"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.delete"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.list"},{"hostname":"servicedirectory.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.get"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints/{endpointsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.patch"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:resolve","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.resolve"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}/endpoints","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/endpoints)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.endpoints.create"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:resolve","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.resolve"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.services.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/workloads/{workloadsId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.workloads.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/workloads/{workloadsId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.workloads.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}/workloads/{workloadsId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workloads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.workloads.testIamPermissions"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:getIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.getIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:setIamPolicy","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.setIamPolicy"},{"hostname":"servicedirectory.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/namespaces/{namespacesId}:testIamPermissions","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/namespaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicedirectory","resource_name":"servicedirectory.projects.locations.namespaces.testIamPermissions"},{"hostname":"servicemanagement.googleapis.com","http_method":"DELETE","path_template":"/v1/services/{serviceName}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.delete"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.operations.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.operations.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services","path_regex":"^(?:/v1/services)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/config","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.getConfig"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/configs","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/configs/{configId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/rollouts","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.rollouts.list"},{"hostname":"servicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/services/{serviceName}/rollouts/{rolloutId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.rollouts.get"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services","path_regex":"^(?:/v1/services)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.create"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}/configs","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.create"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}/configs:submit","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/configs:submit)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.configs.submit"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}/rollouts","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollouts)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.rollouts.create"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{serviceName}:undelete","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.undelete"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/consumers/{consumersId}:getIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.consumers.getIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/consumers/{consumersId}:setIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.consumers.setIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/consumers/{consumersId}:testIamPermissions","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.consumers.testIamPermissions"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:getIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.getIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:setIamPolicy","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.setIamPolicy"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:testIamPermissions","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.testIamPermissions"},{"hostname":"servicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/services:generateConfigReport","path_regex":"^(?:/v1/services:generateConfigReport)$","service_name":"google.servicemanagement","resource_name":"servicemanagement.services.generateConfigReport"},{"hostname":"servicenetworking.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.delete"},{"hostname":"servicenetworking.googleapis.com","http_method":"DELETE","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/peeredDnsDomains/{peeredDnsDomainsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeredDnsDomains/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.peeredDnsDomains.delete"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/connections","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/dnsRecordSets:get","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:get)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/dnsRecordSets:list","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:list)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/dnsZones/{dnsZonesId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsZones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.dnsZones.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/dnsZones:list","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsZones:list)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.dnsZones.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/peeredDnsDomains","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeredDnsDomains)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.peeredDnsDomains.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/vpcServiceControls","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vpcServiceControls)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.getVpcServiceControls"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1beta/operations/{operationsId}","path_regex":"^(?:/v1beta/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.get"},{"hostname":"servicenetworking.googleapis.com","http_method":"GET","path_template":"/v1beta/services/{servicesId}/connections","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.list"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}/connections/{connectionsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.patch"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}:updateConsumerConfig","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::updateConsumerConfig)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.updateConsumerConfig"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}:disableVpcServiceControls","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disableVpcServiceControls)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.disableVpcServiceControls"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1/services/{servicesId}:enableVpcServiceControls","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enableVpcServiceControls)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.enableVpcServiceControls"},{"hostname":"servicenetworking.googleapis.com","http_method":"PATCH","path_template":"/v1beta/services/{servicesId}/connections","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.updateConnections"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.operations.cancel"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/connections","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.create"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/connections/{connectionsId}","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.deleteConnection"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsRecordSets:add","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:add)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.add"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsRecordSets:remove","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:remove)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.remove"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsRecordSets:update","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsRecordSets:update)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsRecordSets.update"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsZones:add","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsZones:add)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsZones.add"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/dnsZones:remove","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsZones:remove)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.dnsZones.remove"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/projects/{projectsId}/global/networks/{networksId}/peeredDnsDomains","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/global/networks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeredDnsDomains)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.projects.global.networks.peeredDnsDomains.create"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/roles:add","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/roles:add)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.roles.add"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}/{servicesId1}/{servicesId2}:addSubnetwork","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addSubnetwork)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.addSubnetwork"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:searchRange","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchRange)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.searchRange"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1/services/{servicesId}:validate","path_regex":"^(?:/v1/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::validate)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.validate"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1beta/services/{servicesId}/connections","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connections)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.connections.create"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1beta/services/{servicesId}/{servicesId1}/{servicesId2}:addSubnetwork","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addSubnetwork)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.addSubnetwork"},{"hostname":"servicenetworking.googleapis.com","http_method":"POST","path_template":"/v1beta/services/{servicesId}:searchRange","path_regex":"^(?:/v1beta/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::searchRange)$","service_name":"google.servicenetworking","resource_name":"servicenetworking.services.searchRange"},{"hostname":"serviceusage.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.delete"},{"hostname":"serviceusage.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides/{adminOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.delete"},{"hostname":"serviceusage.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides/{consumerOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.delete"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/services","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/services/{servicesId}","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/{v1Id1}/services:batchGet","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchGet)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.batchGet"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.get"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.list"},{"hostname":"serviceusage.googleapis.com","http_method":"GET","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.list"},{"hostname":"serviceusage.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides/{adminOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.patch"},{"hostname":"serviceusage.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides/{consumerOverridesId}","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.patch"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.serviceusage","resource_name":"serviceusage.operations.cancel"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/services/{servicesId}:disable","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.disable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/services/{servicesId}:enable","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.enable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1/{v1Id}/{v1Id1}/services:batchEnable","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchEnable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.batchEnable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/adminOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adminOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.adminOverrides.create"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics/{consumerQuotaMetricsId}/limits/{limitsId}/consumerOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/limits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.limits.consumerOverrides.create"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics:importAdminOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics:importAdminOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.importAdminOverrides"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}/consumerQuotaMetrics:importConsumerOverrides","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/consumerQuotaMetrics:importConsumerOverrides)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.consumerQuotaMetrics.importConsumerOverrides"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}:disable","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.disable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}:enable","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.enable"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services/{servicesId}:generateServiceIdentity","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateServiceIdentity)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.generateServiceIdentity"},{"hostname":"serviceusage.googleapis.com","http_method":"POST","path_template":"/v1beta1/{v1beta1Id}/{v1beta1Id1}/services:batchEnable","path_regex":"^(?:/v1beta1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services:batchEnable)$","service_name":"google.serviceusage","resource_name":"serviceusage.services.batchEnable"},{"hostname":"serviceuser.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/services","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services)$","service_name":"google.serviceuser","resource_name":"serviceuser.projects.services.list"},{"hostname":"serviceuser.googleapis.com","http_method":"GET","path_template":"/v1/services:search","path_regex":"^(?:/v1/services:search)$","service_name":"google.serviceuser","resource_name":"serviceuser.services.search"},{"hostname":"serviceuser.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services/{servicesId}:disable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::disable)$","service_name":"google.serviceuser","resource_name":"serviceuser.projects.services.disable"},{"hostname":"serviceuser.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/services/{servicesId}:enable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/services/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::enable)$","service_name":"google.serviceuser","resource_name":"serviceuser.projects.services.enable"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.get"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}/developerMetadata/{metadataId}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developerMetadata/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.developerMetadata.get"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.get"},{"hostname":"sheets.googleapis.com","http_method":"GET","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchGet","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchGet)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchGet"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets","path_regex":"^(?:/v4/spreadsheets)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.create"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/developerMetadata:search","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/developerMetadata:search)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.developerMetadata.search"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/sheets/{sheetId}:copyTo","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::copyTo)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.sheets.copyTo"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}:append","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::append)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.append"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}:clear","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::clear)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.clear"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchClear","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchClear)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchClear"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchClearByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchClearByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchClearByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchGetByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchGetByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchGetByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchUpdate","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchUpdate)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchUpdate"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}/values:batchUpdateByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values:batchUpdateByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.batchUpdateByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}:batchUpdate","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.batchUpdate"},{"hostname":"sheets.googleapis.com","http_method":"POST","path_template":"/v4/spreadsheets/{spreadsheetId}:getByDataFilter","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getByDataFilter)$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.getByDataFilter"},{"hostname":"sheets.googleapis.com","http_method":"PUT","path_template":"/v4/spreadsheets/{spreadsheetId}/values/{range}","path_regex":"^(?:/v4/spreadsheets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/values/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sheets","resource_name":"sheets.spreadsheets.values.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/accounts/{accountId}/labels/{labelId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.labels.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/accounts/{accountId}/returncarrier/{carrierAccountId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.returncarrier.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/collections/{collectionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.collections.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.conversionsources.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/freelistingsprogram/checkoutsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/freelistingsprogram/checkoutsettings)$","service_name":"google.content","resource_name":"content.freelistingsprogram.checkoutsettings.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/productdeliverytime/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productdeliverytime/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productdeliverytime.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/regions/{regionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.regions.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/returnaddress/{returnAddressId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnaddress.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/returnpolicy/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicy.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2.1/{merchantId}/returnpolicyonline/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicyonline.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"DELETE","path_template":"/content/v2/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.delete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/accounts/authinfo","path_regex":"^(?:/content/v2\\.1/accounts/authinfo)$","service_name":"google.content","resource_name":"content.accounts.authinfo"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/accounts/{accountId}/labels","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.content","resource_name":"content.accounts.labels.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/accounts/{accountId}/returncarrier","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier)$","service_name":"google.content","resource_name":"content.accounts.returncarrier.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/liasettings/posdataproviders","path_regex":"^(?:/content/v2\\.1/liasettings/posdataproviders)$","service_name":"google.content","resource_name":"content.liasettings.listposdataproviders"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{cssGroupId}/csses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csses)$","service_name":"google.content","resource_name":"content.csses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{cssGroupId}/csses/{cssDomainId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.csses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounts","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/listlinks","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listlinks)$","service_name":"google.content","resource_name":"content.accounts.listlinks"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accountstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses)$","service_name":"google.content","resource_name":"content.accountstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accountstatuses/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accountstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounttax","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax)$","service_name":"google.content","resource_name":"content.accounttax.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.buyongoogleprograms.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collections","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections)$","service_name":"google.content","resource_name":"content.collections.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collections/{collectionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.collections.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collectionstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionstatuses)$","service_name":"google.content","resource_name":"content.collectionstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/collectionstatuses/{collectionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collectionstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.collectionstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/conversionsources","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources)$","service_name":"google.content","resource_name":"content.conversionsources.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.conversionsources.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeeds","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeedstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses)$","service_name":"google.content","resource_name":"content.datafeedstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/datafeedstatuses/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeedstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/freelistingsprogram","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/freelistingsprogram)$","service_name":"google.content","resource_name":"content.freelistingsprogram.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/freelistingsprogram/checkoutsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/freelistingsprogram/checkoutsettings)$","service_name":"google.content","resource_name":"content.freelistingsprogram.checkoutsettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/liasettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings)$","service_name":"google.content","resource_name":"content.liasettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/accessiblegmbaccounts","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessiblegmbaccounts)$","service_name":"google.content","resource_name":"content.liasettings.getaccessiblegmbaccounts"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreports/disbursements","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements)$","service_name":"google.content","resource_name":"content.orderreports.listdisbursements"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreports/disbursements/{disbursementId}/transactions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transactions)$","service_name":"google.content","resource_name":"content.orderreports.listtransactions"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreturns","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns)$","service_name":"google.content","resource_name":"content.orderreturns.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orderreturns.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orders","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.content","resource_name":"content.orders.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/orders/{orderId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/ordersbymerchantid/{merchantOrderId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordersbymerchantid/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.getbymerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/productdeliverytime/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productdeliverytime/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productdeliverytime.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/products","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/productstatuses","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses)$","service_name":"google.content","resource_name":"content.productstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/productstatuses/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/promotions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions)$","service_name":"google.content","resource_name":"content.promotions.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/promotions/{id}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.promotions.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/pubsubnotificationsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pubsubnotificationsettings)$","service_name":"google.content","resource_name":"content.pubsubnotificationsettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/quotas","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/quotas)$","service_name":"google.content","resource_name":"content.quotas.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/recommendations/generate","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/generate)$","service_name":"google.content","resource_name":"content.recommendations.generate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/regions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.content","resource_name":"content.regions.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/regions/{regionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.regions.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnaddress","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress)$","service_name":"google.content","resource_name":"content.returnaddress.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnaddress/{returnAddressId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnaddress.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicy","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy)$","service_name":"google.content","resource_name":"content.returnpolicy.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicy/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicy.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicyonline","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline)$","service_name":"google.content","resource_name":"content.returnpolicyonline.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/returnpolicyonline/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicyonline.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/settlementreports","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settlementreports)$","service_name":"google.content","resource_name":"content.settlementreports.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/settlementreports/{settlementId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settlementreports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.settlementreports.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/settlementreports/{settlementId}/transactions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settlementreports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transactions)$","service_name":"google.content","resource_name":"content.settlementtransactions.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/shippingsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings)$","service_name":"google.content","resource_name":"content.shippingsettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/shoppingadsprogram","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shoppingadsprogram)$","service_name":"google.content","resource_name":"content.shoppingadsprogram.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/supportedCarriers","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedCarriers)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedcarriers"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/supportedHolidays","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedHolidays)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedholidays"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/supportedPickupServices","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedPickupServices)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedpickupservices"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2.1/{merchantId}/testordertemplates/{templateName}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testordertemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.gettestordertemplate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/accounts/authinfo","path_regex":"^(?:/content/v2/accounts/authinfo)$","service_name":"google.content","resource_name":"content.accounts.authinfo"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/liasettings/posdataproviders","path_regex":"^(?:/content/v2/liasettings/posdataproviders)$","service_name":"google.content","resource_name":"content.liasettings.listposdataproviders"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounts","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accountstatuses","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses)$","service_name":"google.content","resource_name":"content.accountstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accountstatuses/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accountstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounttax","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax)$","service_name":"google.content","resource_name":"content.accounttax.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeeds","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeedstatuses","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses)$","service_name":"google.content","resource_name":"content.datafeedstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/datafeedstatuses/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeedstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeedstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/liasettings","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings)$","service_name":"google.content","resource_name":"content.liasettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/accessiblegmbaccounts","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accessiblegmbaccounts)$","service_name":"google.content","resource_name":"content.liasettings.getaccessiblegmbaccounts"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreports/disbursements","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements)$","service_name":"google.content","resource_name":"content.orderreports.listdisbursements"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreports/disbursements/{disbursementId}/transactions","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreports/disbursements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transactions)$","service_name":"google.content","resource_name":"content.orderreports.listtransactions"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreturns","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns)$","service_name":"google.content","resource_name":"content.orderreturns.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orderreturns/{returnId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orderreturns.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orders","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.content","resource_name":"content.orders.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/orders/{orderId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/ordersbymerchantid/{merchantOrderId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordersbymerchantid/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.getbymerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store/{storeCode}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.pos.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/products","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/productstatuses","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses)$","service_name":"google.content","resource_name":"content.productstatuses.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/productstatuses/{productId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productstatuses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.productstatuses.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/shippingsettings","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings)$","service_name":"google.content","resource_name":"content.shippingsettings.list"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.get"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/supportedCarriers","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedCarriers)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedcarriers"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/supportedHolidays","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedHolidays)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedholidays"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/supportedPickupServices","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedPickupServices)$","service_name":"google.content","resource_name":"content.shippingsettings.getsupportedpickupservices"},{"hostname":"shoppingcontent.googleapis.com","http_method":"GET","path_template":"/content/v2/{merchantId}/testordertemplates/{templateName}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testordertemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.gettestordertemplate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/accounts/{accountId}/labels/{labelId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.labels.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/accounts/{accountId}/returncarrier/{carrierAccountId}","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.returncarrier.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.buyongoogleprograms.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.conversionsources.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/products/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.products.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/regions/{regionId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.regions.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PATCH","path_template":"/content/v2.1/{merchantId}/returnpolicyonline/{returnPolicyId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.returnpolicyonline.patch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/batch","path_regex":"^(?:/content/v2\\.1/accounts/batch)$","service_name":"google.content","resource_name":"content.accounts.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/{accountId}/credentials","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/credentials)$","service_name":"google.content","resource_name":"content.accounts.credentials.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/{accountId}/labels","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.content","resource_name":"content.accounts.labels.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounts/{accountId}/returncarrier","path_regex":"^(?:/content/v2\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returncarrier)$","service_name":"google.content","resource_name":"content.accounts.returncarrier.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accountstatuses/batch","path_regex":"^(?:/content/v2\\.1/accountstatuses/batch)$","service_name":"google.content","resource_name":"content.accountstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/accounttax/batch","path_regex":"^(?:/content/v2\\.1/accounttax/batch)$","service_name":"google.content","resource_name":"content.accounttax.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/datafeeds/batch","path_regex":"^(?:/content/v2\\.1/datafeeds/batch)$","service_name":"google.content","resource_name":"content.datafeeds.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/datafeedstatuses/batch","path_regex":"^(?:/content/v2\\.1/datafeedstatuses/batch)$","service_name":"google.content","resource_name":"content.datafeedstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/liasettings/batch","path_regex":"^(?:/content/v2\\.1/liasettings/batch)$","service_name":"google.content","resource_name":"content.liasettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/localinventory/batch","path_regex":"^(?:/content/v2\\.1/localinventory/batch)$","service_name":"google.content","resource_name":"content.localinventory.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/pos/batch","path_regex":"^(?:/content/v2\\.1/pos/batch)$","service_name":"google.content","resource_name":"content.pos.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/products/batch","path_regex":"^(?:/content/v2\\.1/products/batch)$","service_name":"google.content","resource_name":"content.products.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/productstatuses/batch","path_regex":"^(?:/content/v2\\.1/productstatuses/batch)$","service_name":"google.content","resource_name":"content.productstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/regionalinventory/batch","path_regex":"^(?:/content/v2\\.1/regionalinventory/batch)$","service_name":"google.content","resource_name":"content.regionalinventory.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/returnaddress/batch","path_regex":"^(?:/content/v2\\.1/returnaddress/batch)$","service_name":"google.content","resource_name":"content.returnaddress.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/returnpolicy/batch","path_regex":"^(?:/content/v2\\.1/returnpolicy/batch)$","service_name":"google.content","resource_name":"content.returnpolicy.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/shippingsettings/batch","path_regex":"^(?:/content/v2\\.1/shippingsettings/batch)$","service_name":"google.content","resource_name":"content.shippingsettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{cssGroupId}/csses/{cssDomainId}/updatelabels","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/csses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatelabels)$","service_name":"google.content","resource_name":"content.csses.updatelabels"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/claimwebsite","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/claimwebsite)$","service_name":"google.content","resource_name":"content.accounts.claimwebsite"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/link","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/link)$","service_name":"google.content","resource_name":"content.accounts.link"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/requestphoneverification","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestphoneverification)$","service_name":"google.content","resource_name":"content.accounts.requestphoneverification"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/updatelabels","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updatelabels)$","service_name":"google.content","resource_name":"content.accounts.updatelabels"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}/verifyphonenumber","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyphonenumber)$","service_name":"google.content","resource_name":"content.accounts.verifyphonenumber"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/activate","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activate)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.activate"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/onboard","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/onboard)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.onboard"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/pause","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pause)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.pause"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/buyongoogleprograms/{regionCode}/requestreview","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/buyongoogleprograms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestreview)$","service_name":"google.content","resource_name":"content.buyongoogleprograms.requestreview"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/collections","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/collections)$","service_name":"google.content","resource_name":"content.collections.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/conversionsources","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources)$","service_name":"google.content","resource_name":"content.conversionsources.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/conversionsources/{conversionSourceId}:undelete","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversionsources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.content","resource_name":"content.conversionsources.undelete"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/datafeeds","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}/fetchNow","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fetchNow)$","service_name":"google.content","resource_name":"content.datafeeds.fetchnow"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/freelistingsprogram/checkoutsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/freelistingsprogram/checkoutsettings)$","service_name":"google.content","resource_name":"content.freelistingsprogram.checkoutsettings.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/freelistingsprogram/requestreview","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/freelistingsprogram/requestreview)$","service_name":"google.content","resource_name":"content.freelistingsprogram.requestreview"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/requestgmbaccess","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestgmbaccess)$","service_name":"google.content","resource_name":"content.liasettings.requestgmbaccess"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/requestinventoryverification/{country}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestinventoryverification/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.requestinventoryverification"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/setinventoryverificationcontact","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setinventoryverificationcontact)$","service_name":"google.content","resource_name":"content.liasettings.setinventoryverificationcontact"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/setomnichannelexperience","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setomnichannelexperience)$","service_name":"google.content","resource_name":"content.liasettings.setomnichannelexperience"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}/setposdataprovider","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setposdataprovider)$","service_name":"google.content","resource_name":"content.liasettings.setposdataprovider"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/merchantsupport/renderaccountissues","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantsupport/renderaccountissues)$","service_name":"google.content","resource_name":"content.merchantsupport.renderaccountissues"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/merchantsupport/renderproductissues/{productId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantsupport/renderproductissues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.merchantsupport.renderproductissues"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/merchantsupport/triggeraction","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/merchantsupport/triggeraction)$","service_name":"google.content","resource_name":"content.merchantsupport.triggeraction"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderinvoices/{orderId}/createChargeInvoice","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createChargeInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createchargeinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderinvoices/{orderId}/createRefundInvoice","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createRefundInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createrefundinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/createOrderReturn","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/createOrderReturn)$","service_name":"google.content","resource_name":"content.orderreturns.createorderreturn"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}/acknowledge","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orderreturns.acknowledge"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}/labels","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/labels)$","service_name":"google.content","resource_name":"content.orderreturns.labels.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orderreturns/{returnId}/process","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/process)$","service_name":"google.content","resource_name":"content.orderreturns.process"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/acknowledge","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orders.acknowledge"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/cancel","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.content","resource_name":"content.orders.cancel"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/cancelLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelLineItem)$","service_name":"google.content","resource_name":"content.orders.cancellineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/captureOrder","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/captureOrder)$","service_name":"google.content","resource_name":"content.orders.captureOrder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/inStoreRefundLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inStoreRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.instorerefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/refunditem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refunditem)$","service_name":"google.content","resource_name":"content.orders.refunditem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/refundorder","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refundorder)$","service_name":"google.content","resource_name":"content.orders.refundorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/rejectReturnLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rejectReturnLineItem)$","service_name":"google.content","resource_name":"content.orders.rejectreturnlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/returnRefundLineItem","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.returnrefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/setLineItemMetadata","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLineItemMetadata)$","service_name":"google.content","resource_name":"content.orders.setlineitemmetadata"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/shipLineItems","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shipLineItems)$","service_name":"google.content","resource_name":"content.orders.shiplineitems"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/testreturn","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testreturn)$","service_name":"google.content","resource_name":"content.orders.createtestreturn"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/updateLineItemShippingDetails","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateLineItemShippingDetails)$","service_name":"google.content","resource_name":"content.orders.updatelineitemshippingdetails"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/updateMerchantOrderId","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateMerchantOrderId)$","service_name":"google.content","resource_name":"content.orders.updatemerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/orders/{orderId}/updateShipment","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShipment)$","service_name":"google.content","resource_name":"content.orders.updateshipment"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/ordertrackingsignals","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordertrackingsignals)$","service_name":"google.content","resource_name":"content.ordertrackingsignals.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/inventory","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.content","resource_name":"content.pos.inventory"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/sale","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sale)$","service_name":"google.content","resource_name":"content.pos.sale"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/productdeliverytime","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productdeliverytime)$","service_name":"google.content","resource_name":"content.productdeliverytime.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/products","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/products/{productId}/localinventory","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/localinventory)$","service_name":"google.content","resource_name":"content.localinventory.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/products/{productId}/regionalinventory","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regionalinventory)$","service_name":"google.content","resource_name":"content.regionalinventory.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/promotions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promotions)$","service_name":"google.content","resource_name":"content.promotions.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/recommendations/reportInteraction","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/recommendations/reportInteraction)$","service_name":"google.content","resource_name":"content.recommendations.reportInteraction"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/regions","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.content","resource_name":"content.regions.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/reports/search","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/search)$","service_name":"google.content","resource_name":"content.reports.search"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/returnaddress","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnaddress)$","service_name":"google.content","resource_name":"content.returnaddress.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/returnpolicy","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicy)$","service_name":"google.content","resource_name":"content.returnpolicy.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/returnpolicyonline","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnpolicyonline)$","service_name":"google.content","resource_name":"content.returnpolicyonline.create"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/shoppingadsprogram/requestreview","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shoppingadsprogram/requestreview)$","service_name":"google.content","resource_name":"content.shoppingadsprogram.requestreview"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/testorders","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders)$","service_name":"google.content","resource_name":"content.orders.createtestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/testorders/{orderId}/advance","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advance)$","service_name":"google.content","resource_name":"content.orders.advancetestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2.1/{merchantId}/testorders/{orderId}/cancelByCustomer","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelByCustomer)$","service_name":"google.content","resource_name":"content.orders.canceltestorderbycustomer"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/accounts/batch","path_regex":"^(?:/content/v2/accounts/batch)$","service_name":"google.content","resource_name":"content.accounts.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/accountstatuses/batch","path_regex":"^(?:/content/v2/accountstatuses/batch)$","service_name":"google.content","resource_name":"content.accountstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/accounttax/batch","path_regex":"^(?:/content/v2/accounttax/batch)$","service_name":"google.content","resource_name":"content.accounttax.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/datafeeds/batch","path_regex":"^(?:/content/v2/datafeeds/batch)$","service_name":"google.content","resource_name":"content.datafeeds.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/datafeedstatuses/batch","path_regex":"^(?:/content/v2/datafeedstatuses/batch)$","service_name":"google.content","resource_name":"content.datafeedstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/liasettings/batch","path_regex":"^(?:/content/v2/liasettings/batch)$","service_name":"google.content","resource_name":"content.liasettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/orders/batch","path_regex":"^(?:/content/v2/orders/batch)$","service_name":"google.content","resource_name":"content.orders.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/pos/batch","path_regex":"^(?:/content/v2/pos/batch)$","service_name":"google.content","resource_name":"content.pos.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/products/batch","path_regex":"^(?:/content/v2/products/batch)$","service_name":"google.content","resource_name":"content.products.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/productstatuses/batch","path_regex":"^(?:/content/v2/productstatuses/batch)$","service_name":"google.content","resource_name":"content.productstatuses.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/shippingsettings/batch","path_regex":"^(?:/content/v2/shippingsettings/batch)$","service_name":"google.content","resource_name":"content.shippingsettings.custombatch"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/accounts","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.content","resource_name":"content.accounts.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/accounts/{accountId}/claimwebsite","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/claimwebsite)$","service_name":"google.content","resource_name":"content.accounts.claimwebsite"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/accounts/{accountId}/link","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/link)$","service_name":"google.content","resource_name":"content.accounts.link"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/datafeeds","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds)$","service_name":"google.content","resource_name":"content.datafeeds.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}/fetchNow","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/fetchNow)$","service_name":"google.content","resource_name":"content.datafeeds.fetchnow"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/requestgmbaccess","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestgmbaccess)$","service_name":"google.content","resource_name":"content.liasettings.requestgmbaccess"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/requestinventoryverification/{country}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/requestinventoryverification/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.requestinventoryverification"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/setinventoryverificationcontact","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setinventoryverificationcontact)$","service_name":"google.content","resource_name":"content.liasettings.setinventoryverificationcontact"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/liasettings/{accountId}/setposdataprovider","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setposdataprovider)$","service_name":"google.content","resource_name":"content.liasettings.setposdataprovider"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orderinvoices/{orderId}/createChargeInvoice","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createChargeInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createchargeinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orderinvoices/{orderId}/createRefundInvoice","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createRefundInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createrefundinvoice"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/acknowledge","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orders.acknowledge"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/cancel","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.content","resource_name":"content.orders.cancel"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/cancelLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelLineItem)$","service_name":"google.content","resource_name":"content.orders.cancellineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/inStoreRefundLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inStoreRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.instorerefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/refund","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refund)$","service_name":"google.content","resource_name":"content.orders.refund"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/rejectReturnLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rejectReturnLineItem)$","service_name":"google.content","resource_name":"content.orders.rejectreturnlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/returnLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnLineItem)$","service_name":"google.content","resource_name":"content.orders.returnlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/returnRefundLineItem","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.returnrefundlineitem"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/setLineItemMetadata","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLineItemMetadata)$","service_name":"google.content","resource_name":"content.orders.setlineitemmetadata"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/shipLineItems","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shipLineItems)$","service_name":"google.content","resource_name":"content.orders.shiplineitems"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/testreturn","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testreturn)$","service_name":"google.content","resource_name":"content.orders.createtestreturn"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/updateLineItemShippingDetails","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateLineItemShippingDetails)$","service_name":"google.content","resource_name":"content.orders.updatelineitemshippingdetails"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/updateMerchantOrderId","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateMerchantOrderId)$","service_name":"google.content","resource_name":"content.orders.updatemerchantorderid"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/orders/{orderId}/updateShipment","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShipment)$","service_name":"google.content","resource_name":"content.orders.updateshipment"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/inventory","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventory)$","service_name":"google.content","resource_name":"content.pos.inventory"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/sale","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sale)$","service_name":"google.content","resource_name":"content.pos.sale"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/pos/{targetMerchantId}/store","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/store)$","service_name":"google.content","resource_name":"content.pos.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/products","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.content","resource_name":"content.products.insert"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/testorders","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders)$","service_name":"google.content","resource_name":"content.orders.createtestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/testorders/{orderId}/advance","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advance)$","service_name":"google.content","resource_name":"content.orders.advancetestorder"},{"hostname":"shoppingcontent.googleapis.com","http_method":"POST","path_template":"/content/v2/{merchantId}/testorders/{orderId}/cancelByCustomer","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelByCustomer)$","service_name":"google.content","resource_name":"content.orders.canceltestorderbycustomer"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/pubsubnotificationsettings","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pubsubnotificationsettings)$","service_name":"google.content","resource_name":"content.pubsubnotificationsettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2.1/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2\\.1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/accounts/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounts.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/accounttax/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounttax/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.accounttax.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/datafeeds/{datafeedId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datafeeds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.datafeeds.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/liasettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/liasettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.liasettings.update"},{"hostname":"shoppingcontent.googleapis.com","http_method":"PUT","path_template":"/content/v2/{merchantId}/shippingsettings/{accountId}","path_regex":"^(?:/content/v2/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shippingsettings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.shippingsettings.update"},{"hostname":"slides.googleapis.com","http_method":"GET","path_template":"/v1/presentations/{presentationId}/pages/{pageObjectId}","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.slides","resource_name":"slides.presentations.pages.get"},{"hostname":"slides.googleapis.com","http_method":"GET","path_template":"/v1/presentations/{presentationId}/pages/{pageObjectId}/thumbnail","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/thumbnail)$","service_name":"google.slides","resource_name":"slides.presentations.pages.getThumbnail"},{"hostname":"slides.googleapis.com","http_method":"GET","path_template":"/v1/presentations/{presentationsId}","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.slides","resource_name":"slides.presentations.get"},{"hostname":"slides.googleapis.com","http_method":"POST","path_template":"/v1/presentations","path_regex":"^(?:/v1/presentations)$","service_name":"google.slides","resource_name":"slides.presentations.create"},{"hostname":"slides.googleapis.com","http_method":"POST","path_template":"/v1/presentations/{presentationId}:batchUpdate","path_regex":"^(?:/v1/presentations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchUpdate)$","service_name":"google.slides","resource_name":"slides.presentations.batchUpdate"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.devices.list"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.devices.get"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.list"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures/{structuresId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.get"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures/{structuresId}/rooms","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rooms)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.rooms.list"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"GET","path_template":"/v1/enterprises/{enterprisesId}/structures/{structuresId}/rooms/{roomsId}","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/structures/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rooms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.structures.rooms.get"},{"hostname":"smartdevicemanagement.googleapis.com","http_method":"POST","path_template":"/v1/enterprises/{enterprisesId}/devices/{devicesId}:executeCommand","path_regex":"^(?:/v1/enterprises/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/devices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeCommand)$","service_name":"google.smartdevicemanagement","resource_name":"smartdevicemanagement.enterprises.devices.executeCommand"},{"hostname":"solar.googleapis.com","http_method":"GET","path_template":"/v1/buildingInsights:findClosest","path_regex":"^(?:/v1/buildingInsights:findClosest)$","service_name":"google.solar","resource_name":"solar.buildingInsights.findClosest"},{"hostname":"solar.googleapis.com","http_method":"GET","path_template":"/v1/dataLayers:get","path_regex":"^(?:/v1/dataLayers:get)$","service_name":"google.solar","resource_name":"solar.dataLayers.get"},{"hostname":"solar.googleapis.com","http_method":"GET","path_template":"/v1/geoTiff:get","path_regex":"^(?:/v1/geoTiff:get)$","service_name":"google.solar","resource_name":"solar.geoTiff.get"},{"hostname":"sourcerepo.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/repos/{reposId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.delete"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.getConfig"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.list"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/repos/{reposId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.get"},{"hostname":"sourcerepo.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/repos/{reposId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.getIamPolicy"},{"hostname":"sourcerepo.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/config","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/config)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.updateConfig"},{"hostname":"sourcerepo.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/repos/{reposId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.patch"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.create"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos/{reposId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.setIamPolicy"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos/{reposId}:sync","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sync)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.sync"},{"hostname":"sourcerepo.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/repos/{reposId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/repos/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.sourcerepo","resource_name":"sourcerepo.projects.repos.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/ssdCaches/{ssdCachesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ssdCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.ssdCaches.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.dropDatabase"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions/{instancePartitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions/{instancePartitionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.delete"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigOperations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigOperations)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigOperations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/ssdCaches/{ssdCachesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ssdCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.ssdCaches.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/ssdCaches/{ssdCachesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ssdCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.ssdCaches.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backupOperations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupOperations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backupOperations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databaseOperations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databaseOperations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databaseOperations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/databaseRoles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databaseRoles)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.databaseRoles.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/ddl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ddl)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.getDdl"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/scans","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scans)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.getScans"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitionOperations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitionOperations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitionOperations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions/{instancePartitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions/{instancePartitionsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions/{instancePartitionsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.list"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.get"},{"hostname":"spanner.googleapis.com","http_method":"GET","path_template":"/v1/scans","path_regex":"^(?:/v1/scans)$","service_name":"google.spanner","resource_name":"spanner.scans.list"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.patch"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/ddl","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ddl)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.updateDdl"},{"hostname":"spanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions/{instancePartitionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.patch"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instanceConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instanceConfigs/{instanceConfigsId}/ssdCaches/{ssdCachesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ssdCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instanceConfigs.ssdCaches.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.getIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.setIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups/{backupsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/backups:copy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backups:copy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.backups.copy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.getIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.setIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/backupSchedules/{backupSchedulesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupSchedules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.backupSchedules.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/databaseRoles/{databaseRolesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databaseRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.databaseRoles.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:batchWrite","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchWrite)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.batchWrite"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:beginTransaction","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::beginTransaction)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.beginTransaction"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:commit","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::commit)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.commit"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:executeBatchDml","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeBatchDml)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.executeBatchDml"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:executeSql","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeSql)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.executeSql"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:executeStreamingSql","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::executeStreamingSql)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.executeStreamingSql"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:partitionQuery","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionQuery)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.partitionQuery"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:partitionRead","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::partitionRead)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.partitionRead"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:read","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::read)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.read"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:rollback","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::rollback)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.rollback"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions/{sessionsId}:streamingRead","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::streamingRead)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.streamingRead"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}/sessions:batchCreate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sessions:batchCreate)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.sessions.batchCreate"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}:changequorum","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::changequorum)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.changequorum"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.getIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.setIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases/{databasesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.testIamPermissions"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/databases:restore","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases:restore)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.databases.restore"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.create"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/instancePartitions/{instancePartitionsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instancePartitions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.instancePartitions.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.operations.cancel"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.getIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}:move","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.move"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.setIamPolicy"},{"hostname":"spanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/instances/{instancesId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.spanner","resource_name":"spanner.projects.instances.testIamPermissions"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.delete"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.delete"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.delete"},{"hostname":"speech.googleapis.com","http_method":"DELETE","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.delete"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.speech","resource_name":"speech.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations","path_regex":"^(?:/v1beta1/operations)$","service_name":"google.speech","resource_name":"speech.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1beta1/operations/{operationsId}","path_regex":"^(?:/v1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/operations","path_regex":"^(?:/v1p1beta1/operations)$","service_name":"google.speech","resource_name":"speech.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/operations/{operationsId}","path_regex":"^(?:/v1p1beta1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.get"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.list"},{"hostname":"speech.googleapis.com","http_method":"GET","path_template":"/v2beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.operations.get"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.patch"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.patch"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses/{customClassesId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.patch"},{"hostname":"speech.googleapis.com","http_method":"PATCH","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets/{phraseSetsId}","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.patch"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/speech:longrunningrecognize","path_regex":"^(?:/v1/speech:longrunningrecognize)$","service_name":"google.speech","resource_name":"speech.speech.longrunningrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1/speech:recognize","path_regex":"^(?:/v1/speech:recognize)$","service_name":"google.speech","resource_name":"speech.speech.recognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1beta1/speech:asyncrecognize","path_regex":"^(?:/v1beta1/speech:asyncrecognize)$","service_name":"google.speech","resource_name":"speech.speech.asyncrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1beta1/speech:syncrecognize","path_regex":"^(?:/v1beta1/speech:syncrecognize)$","service_name":"google.speech","resource_name":"speech.speech.syncrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/customClasses","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customClasses)$","service_name":"google.speech","resource_name":"speech.projects.locations.customClasses.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/phraseSets","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/phraseSets)$","service_name":"google.speech","resource_name":"speech.projects.locations.phraseSets.create"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/speech:longrunningrecognize","path_regex":"^(?:/v1p1beta1/speech:longrunningrecognize)$","service_name":"google.speech","resource_name":"speech.speech.longrunningrecognize"},{"hostname":"speech.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/speech:recognize","path_regex":"^(?:/v1p1beta1/speech:recognize)$","service_name":"google.speech","resource_name":"speech.speech.recognize"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.backupRuns.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.sslCerts.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.delete"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/flags","path_regex":"^(?:/sql/v1beta4/flags)$","service_name":"google.sql","resource_name":"sql.flags.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/flags","path_regex":"^(?:/sql/v1beta4/flags)$","service_name":"google.sqladmin","resource_name":"sql.flags.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sql","resource_name":"sql.instances.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sql","resource_name":"sql.backupRuns.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.backupRuns.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/connectSettings","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectSettings)$","service_name":"google.sqladmin","resource_name":"sql.connect.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sql","resource_name":"sql.databases.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/getDiskShrinkConfig","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiskShrinkConfig)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.getDiskShrinkConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/getLatestRecoveryTime","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getLatestRecoveryTime)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.getLatestRecoveryTime"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/listServerCas","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listServerCas)$","service_name":"google.sql","resource_name":"sql.instances.listServerCas"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/listServerCas","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listServerCas)$","service_name":"google.sqladmin","resource_name":"sql.instances.listServerCas"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sql","resource_name":"sql.sslCerts.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.sslCerts.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users/{name}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.users.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.sql","resource_name":"sql.operations.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.sqladmin","resource_name":"sql.operations.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations/{operation}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.operations.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/operations/{operation}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.operations.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/tiers","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tiers)$","service_name":"google.sql","resource_name":"sql.tiers.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/sql/v1beta4/projects/{project}/tiers","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tiers)$","service_name":"google.sqladmin","resource_name":"sql.tiers.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/flags","path_regex":"^(?:/v1/flags)$","service_name":"google.sqladmin","resource_name":"sql.flags.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns/{id}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/connectSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectSettings)$","service_name":"google.sqladmin","resource_name":"sql.connect.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/getDiskShrinkConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getDiskShrinkConfig)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.getDiskShrinkConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/getLatestRecoveryTime","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/getLatestRecoveryTime)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.getLatestRecoveryTime"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/listServerCas","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listServerCas)$","service_name":"google.sqladmin","resource_name":"sql.instances.listServerCas"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts/{sha1Fingerprint}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/instances/{instance}/users/{name}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.users.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.sqladmin","resource_name":"sql.operations.list"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/operations/{operation}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.operations.get"},{"hostname":"sqladmin.googleapis.com","http_method":"GET","path_template":"/v1/projects/{project}/tiers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tiers)$","service_name":"google.sqladmin","resource_name":"sql.tiers.list"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.patch"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sql","resource_name":"sql.instances.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/acquireSsrsLease","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acquireSsrsLease)$","service_name":"google.sqladmin","resource_name":"sql.instances.acquireSsrsLease"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/addServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addServerCa)$","service_name":"google.sql","resource_name":"sql.instances.addServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/addServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.addServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sql","resource_name":"sql.backupRuns.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/clone","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clone)$","service_name":"google.sql","resource_name":"sql.instances.clone"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/clone","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clone)$","service_name":"google.sqladmin","resource_name":"sql.instances.clone"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/createEphemeral","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEphemeral)$","service_name":"google.sql","resource_name":"sql.sslCerts.createEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/createEphemeral","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEphemeral)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.createEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sql","resource_name":"sql.databases.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/demote","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demote)$","service_name":"google.sqladmin","resource_name":"sql.instances.demote"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/demoteMaster","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demoteMaster)$","service_name":"google.sql","resource_name":"sql.instances.demoteMaster"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/demoteMaster","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demoteMaster)$","service_name":"google.sqladmin","resource_name":"sql.instances.demoteMaster"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/export","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.sql","resource_name":"sql.instances.export"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/export","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.sqladmin","resource_name":"sql.instances.export"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/failover","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/failover)$","service_name":"google.sql","resource_name":"sql.instances.failover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/failover","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/failover)$","service_name":"google.sqladmin","resource_name":"sql.instances.failover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/import","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.sql","resource_name":"sql.instances.import"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/import","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.sqladmin","resource_name":"sql.instances.import"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/performDiskShrink","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performDiskShrink)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.performDiskShrink"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/promoteReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promoteReplica)$","service_name":"google.sql","resource_name":"sql.instances.promoteReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/promoteReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promoteReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.promoteReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/reencrypt","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reencrypt)$","service_name":"google.sqladmin","resource_name":"sql.instances.reencrypt"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/releaseSsrsLease","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseSsrsLease)$","service_name":"google.sqladmin","resource_name":"sql.instances.releaseSsrsLease"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rescheduleMaintenance","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rescheduleMaintenance)$","service_name":"google.sql","resource_name":"sql.projects.instances.rescheduleMaintenance"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rescheduleMaintenance","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rescheduleMaintenance)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.rescheduleMaintenance"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/resetReplicaSize","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetReplicaSize)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.resetReplicaSize"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/resetSslConfig","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetSslConfig)$","service_name":"google.sql","resource_name":"sql.instances.resetSslConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/resetSslConfig","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetSslConfig)$","service_name":"google.sqladmin","resource_name":"sql.instances.resetSslConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restart","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.sql","resource_name":"sql.instances.restart"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restart","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.sqladmin","resource_name":"sql.instances.restart"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restoreBackup","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restoreBackup)$","service_name":"google.sql","resource_name":"sql.instances.restoreBackup"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/restoreBackup","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restoreBackup)$","service_name":"google.sqladmin","resource_name":"sql.instances.restoreBackup"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rotateServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rotateServerCa)$","service_name":"google.sql","resource_name":"sql.instances.rotateServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/rotateServerCa","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rotateServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.rotateServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sql","resource_name":"sql.sslCerts.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startExternalSync","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startExternalSync)$","service_name":"google.sql","resource_name":"sql.projects.instances.startExternalSync"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startExternalSync","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startExternalSync)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.startExternalSync"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startReplica)$","service_name":"google.sql","resource_name":"sql.instances.startReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/startReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.startReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/stopReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopReplica)$","service_name":"google.sql","resource_name":"sql.instances.stopReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/stopReplica","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.stopReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/switchover","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchover)$","service_name":"google.sqladmin","resource_name":"sql.instances.switchover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/truncateLog","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/truncateLog)$","service_name":"google.sql","resource_name":"sql.instances.truncateLog"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/truncateLog","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/truncateLog)$","service_name":"google.sqladmin","resource_name":"sql.instances.truncateLog"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/verifyExternalSyncSettings","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyExternalSyncSettings)$","service_name":"google.sql","resource_name":"sql.projects.instances.verifyExternalSyncSettings"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/verifyExternalSyncSettings","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyExternalSyncSettings)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.verifyExternalSyncSettings"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}:generateEphemeralCert","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateEphemeralCert)$","service_name":"google.sqladmin","resource_name":"sql.connect.generateEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/sql/v1beta4/projects/{project}/operations/{operation}/cancel","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.sqladmin","resource_name":"sql.operations.cancel"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.sqladmin","resource_name":"sql.instances.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/acquireSsrsLease","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acquireSsrsLease)$","service_name":"google.sqladmin","resource_name":"sql.instances.acquireSsrsLease"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/addServerCa","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.addServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/backupRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/backupRuns)$","service_name":"google.sqladmin","resource_name":"sql.backupRuns.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/clone","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clone)$","service_name":"google.sqladmin","resource_name":"sql.instances.clone"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/createEphemeral","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createEphemeral)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.createEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/databases","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases)$","service_name":"google.sqladmin","resource_name":"sql.databases.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/demote","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demote)$","service_name":"google.sqladmin","resource_name":"sql.instances.demote"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/demoteMaster","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/demoteMaster)$","service_name":"google.sqladmin","resource_name":"sql.instances.demoteMaster"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/export","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.sqladmin","resource_name":"sql.instances.export"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/failover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/failover)$","service_name":"google.sqladmin","resource_name":"sql.instances.failover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.sqladmin","resource_name":"sql.instances.import"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/performDiskShrink","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/performDiskShrink)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.performDiskShrink"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/promoteReplica","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/promoteReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.promoteReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/reencrypt","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reencrypt)$","service_name":"google.sqladmin","resource_name":"sql.instances.reencrypt"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/releaseSsrsLease","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releaseSsrsLease)$","service_name":"google.sqladmin","resource_name":"sql.instances.releaseSsrsLease"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/rescheduleMaintenance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rescheduleMaintenance)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.rescheduleMaintenance"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/resetReplicaSize","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetReplicaSize)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.resetReplicaSize"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/resetSslConfig","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resetSslConfig)$","service_name":"google.sqladmin","resource_name":"sql.instances.resetSslConfig"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/restart","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.sqladmin","resource_name":"sql.instances.restart"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/restoreBackup","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restoreBackup)$","service_name":"google.sqladmin","resource_name":"sql.instances.restoreBackup"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/rotateServerCa","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rotateServerCa)$","service_name":"google.sqladmin","resource_name":"sql.instances.rotateServerCa"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/sslCerts","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sslCerts)$","service_name":"google.sqladmin","resource_name":"sql.sslCerts.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/startExternalSync","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startExternalSync)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.startExternalSync"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/startReplica","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/startReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.startReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/stopReplica","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stopReplica)$","service_name":"google.sqladmin","resource_name":"sql.instances.stopReplica"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/switchover","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/switchover)$","service_name":"google.sqladmin","resource_name":"sql.instances.switchover"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/truncateLog","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/truncateLog)$","service_name":"google.sqladmin","resource_name":"sql.instances.truncateLog"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.insert"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}/verifyExternalSyncSettings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/verifyExternalSyncSettings)$","service_name":"google.sqladmin","resource_name":"sql.projects.instances.verifyExternalSyncSettings"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/instances/{instance}:generateEphemeralCert","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateEphemeralCert)$","service_name":"google.sqladmin","resource_name":"sql.connect.generateEphemeral"},{"hostname":"sqladmin.googleapis.com","http_method":"POST","path_template":"/v1/projects/{project}/operations/{operation}/cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.sqladmin","resource_name":"sql.operations.cancel"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.instances.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sql","resource_name":"sql.databases.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sql","resource_name":"sql.users.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/sql/v1beta4/projects/{project}/instances/{instance}/users","path_regex":"^(?:/sql/v1beta4/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{project}/instances/{instance}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.instances.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{project}/instances/{instance}/databases/{database}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/databases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.sqladmin","resource_name":"sql.databases.update"},{"hostname":"sqladmin.googleapis.com","http_method":"PUT","path_template":"/v1/projects/{project}/instances/{instance}/users","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/users)$","service_name":"google.sqladmin","resource_name":"sql.users.update"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/folders/{folder}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.folders.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/managedFolders/{managedFolder}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedFolders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.managedFolders.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/notificationConfigs/{notification}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.notifications.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1/projects/{projectId}/hmacKeys/{accessId}","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.delete"},{"hostname":"storage.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.delete"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b","path_regex":"^(?:/storage/v1/b)$","service_name":"google.storage","resource_name":"storage.buckets.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/anywhereCaches","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anywhereCaches)$","service_name":"google.storage","resource_name":"storage.anywhereCaches.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/anywhereCaches/{anywhereCacheId}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anywhereCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.anywhereCaches.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/folders","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.storage","resource_name":"storage.folders.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/folders/{folder}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.folders.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.buckets.getIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/iam/testPermissions","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam/testPermissions)$","service_name":"google.storage","resource_name":"storage.buckets.testIamPermissions"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/managedFolders","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedFolders)$","service_name":"google.storage","resource_name":"storage.managedFolders.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/managedFolders/{managedFolder}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedFolders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.managedFolders.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/managedFolders/{managedFolder}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedFolders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.managedFolders.getIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/managedFolders/{managedFolder}/iam/testPermissions","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedFolders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam/testPermissions)$","service_name":"google.storage","resource_name":"storage.managedFolders.testIamPermissions"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/notificationConfigs","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.storage","resource_name":"storage.notifications.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/notificationConfigs/{notification}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.notifications.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.objects.getIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/o/{object}/iam/testPermissions","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam/testPermissions)$","service_name":"google.storage","resource_name":"storage.objects.testIamPermissions"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/operations","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.storage","resource_name":"storage.buckets.operations.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/operations/{operationId}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.operations.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}/storageLayout","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/storageLayout)$","service_name":"google.storage","resource_name":"storage.buckets.getStorageLayout"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/projects/{projectId}/hmacKeys","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys)$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/projects/{projectId}/hmacKeys/{accessId}","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1/projects/{projectId}/serviceAccount","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/serviceAccount)$","service_name":"google.storage","resource_name":"storage.projects.serviceAccount.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b","path_regex":"^(?:/storage/v1beta2/b)$","service_name":"google.storage","resource_name":"storage.buckets.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.get"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.list"},{"hostname":"storage.googleapis.com","http_method":"GET","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.get"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/anywhereCaches/{anywhereCacheId}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anywhereCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.anywhereCaches.update"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.patch"},{"hostname":"storage.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.patch"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b","path_regex":"^(?:/storage/v1/b)$","service_name":"google.storage","resource_name":"storage.buckets.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/anywhereCaches","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anywhereCaches)$","service_name":"google.storage","resource_name":"storage.anywhereCaches.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/anywhereCaches/{anywhereCacheId}/disable","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anywhereCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/disable)$","service_name":"google.storage","resource_name":"storage.anywhereCaches.disable"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/anywhereCaches/{anywhereCacheId}/pause","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anywhereCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pause)$","service_name":"google.storage","resource_name":"storage.anywhereCaches.pause"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/anywhereCaches/{anywhereCacheId}/resume","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/anywhereCaches/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.storage","resource_name":"storage.anywhereCaches.resume"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/folders","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.storage","resource_name":"storage.folders.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/folders/{sourceFolder}/renameTo/folders/{destinationFolder}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/renameTo/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.folders.rename"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/lockRetentionPolicy","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/lockRetentionPolicy)$","service_name":"google.storage","resource_name":"storage.buckets.lockRetentionPolicy"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/managedFolders","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedFolders)$","service_name":"google.storage","resource_name":"storage.managedFolders.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/notificationConfigs","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notificationConfigs)$","service_name":"google.storage","resource_name":"storage.notifications.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o/bulkRestore","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/bulkRestore)$","service_name":"google.storage","resource_name":"storage.objects.bulkRestore"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o/watch","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/watch)$","service_name":"google.storage","resource_name":"storage.objects.watchAll"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/o/{object}/restore","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restore)$","service_name":"google.storage","resource_name":"storage.objects.restore"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/operations/{operationId}/cancel","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.storage","resource_name":"storage.buckets.operations.cancel"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{bucket}/restore","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restore)$","service_name":"google.storage","resource_name":"storage.buckets.restore"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{destinationBucket}/o/{destinationObject}/compose","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compose)$","service_name":"google.storage","resource_name":"storage.objects.compose"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{sourceBucket}/o/{sourceObject}/copyTo/b/{destinationBucket}/o/{destinationObject}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyTo/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.copy"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/b/{sourceBucket}/o/{sourceObject}/rewriteTo/b/{destinationBucket}/o/{destinationObject}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rewriteTo/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.rewrite"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/channels/stop","path_regex":"^(?:/storage/v1/channels/stop)$","service_name":"google.storage","resource_name":"storage.channels.stop"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1/projects/{projectId}/hmacKeys","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys)$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.create"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b","path_regex":"^(?:/storage/v1beta2/b)$","service_name":"google.storage","resource_name":"storage.buckets.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl)$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/o","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/o/watch","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/watch)$","service_name":"google.storage","resource_name":"storage.objects.watchAll"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.insert"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{destinationBucket}/o/{destinationObject}/compose","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/compose)$","service_name":"google.storage","resource_name":"storage.objects.compose"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/b/{sourceBucket}/o/{sourceObject}/copyTo/b/{destinationBucket}/o/{destinationObject}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copyTo/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.copy"},{"hostname":"storage.googleapis.com","http_method":"POST","path_template":"/storage/v1beta2/channels/stop","path_regex":"^(?:/storage/v1beta2/channels/stop)$","service_name":"google.storage","resource_name":"storage.channels.stop"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.buckets.setIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/managedFolders/{managedFolder}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managedFolders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.managedFolders.setIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/b/{bucket}/o/{object}/iam","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/iam)$","service_name":"google.storage","resource_name":"storage.objects.setIamPolicy"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1/projects/{projectId}/hmacKeys/{accessId}","path_regex":"^(?:/storage/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hmacKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.projects.hmacKeys.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/defaultObjectAcl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/defaultObjectAcl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.defaultObjectAccessControls.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.update"},{"hostname":"storage.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta2/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta2/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.update"},{"hostname":"storagetransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/agentPools/{agentPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.delete"},{"hostname":"storagetransfer.googleapis.com","http_method":"DELETE","path_template":"/v1/transferJobs/{transferJobsId}","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.delete"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/googleServiceAccounts/{projectId}","path_regex":"^(?:/v1/googleServiceAccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.googleServiceAccounts.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/agentPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.list"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/agentPools/{agentPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferJobs","path_regex":"^(?:/v1/transferJobs)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.list"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferJobs/{transferJobsId}","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferOperations","path_regex":"^(?:/v1/transferOperations)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.list"},{"hostname":"storagetransfer.googleapis.com","http_method":"GET","path_template":"/v1/transferOperations/{transferOperationsId}","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.get"},{"hostname":"storagetransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/agentPools/{agentPoolsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.patch"},{"hostname":"storagetransfer.googleapis.com","http_method":"PATCH","path_template":"/v1/transferJobs/{transferJobsId}","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.patch"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/agentPools","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/agentPools)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.projects.agentPools.create"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferJobs","path_regex":"^(?:/v1/transferJobs)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.create"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferJobs/{transferJobsId}:run","path_regex":"^(?:/v1/transferJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferJobs.run"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferOperations/{transferOperationsId}:cancel","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.cancel"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferOperations/{transferOperationsId}:pause","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pause)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.pause"},{"hostname":"storagetransfer.googleapis.com","http_method":"POST","path_template":"/v1/transferOperations/{transferOperationsId}:resume","path_regex":"^(?:/v1/transferOperations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resume)$","service_name":"google.storagetransfer","resource_name":"storagetransfer.transferOperations.resume"},{"hostname":"streetviewpublish.googleapis.com","http_method":"DELETE","path_template":"/v1/photo/{photoId}","path_regex":"^(?:/v1/photo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.delete"},{"hostname":"streetviewpublish.googleapis.com","http_method":"DELETE","path_template":"/v1/photoSequence/{sequenceId}","path_regex":"^(?:/v1/photoSequence/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.delete"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photo/{photoId}","path_regex":"^(?:/v1/photo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.get"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photoSequence/{sequenceId}","path_regex":"^(?:/v1/photoSequence/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.get"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photoSequences","path_regex":"^(?:/v1/photoSequences)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequences.list"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photos","path_regex":"^(?:/v1/photos)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.list"},{"hostname":"streetviewpublish.googleapis.com","http_method":"GET","path_template":"/v1/photos:batchGet","path_regex":"^(?:/v1/photos:batchGet)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.batchGet"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photo","path_regex":"^(?:/v1/photo)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.create"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photo:startUpload","path_regex":"^(?:/v1/photo:startUpload)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.startUpload"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photoSequence","path_regex":"^(?:/v1/photoSequence)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.create"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photoSequence:startUpload","path_regex":"^(?:/v1/photoSequence:startUpload)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photoSequence.startUpload"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photos:batchDelete","path_regex":"^(?:/v1/photos:batchDelete)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.batchDelete"},{"hostname":"streetviewpublish.googleapis.com","http_method":"POST","path_template":"/v1/photos:batchUpdate","path_regex":"^(?:/v1/photos:batchUpdate)$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photos.batchUpdate"},{"hostname":"streetviewpublish.googleapis.com","http_method":"PUT","path_template":"/v1/photo/{id}","path_regex":"^(?:/v1/photo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.streetviewpublish","resource_name":"streetviewpublish.photo.update"},{"hostname":"sts.googleapis.com","http_method":"POST","path_template":"/v1/token","path_regex":"^(?:/v1/token)$","service_name":"google.sts","resource_name":"sts.token"},{"hostname":"sts.googleapis.com","http_method":"POST","path_template":"/v1beta/token","path_regex":"^(?:/v1beta/token)$","service_name":"google.sts","resource_name":"sts.token"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags/{tagId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers/{triggerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables/{variableId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v1/accounts/{accountId}/permissions/{permissionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config/{gtag_configId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/transformations/{transformationsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transformations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.transformations.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"DELETE","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions/{user_permissionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.delete"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts","path_regex":"^(?:/tagmanager/v1/accounts)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}/entities","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/entities)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.entities.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags/{tagId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers/{triggerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables/{variableId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/permissions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v1/accounts/{accountId}/permissions/{permissionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts","path_regex":"^(?:/tagmanager/v2/accounts)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/containers:lookup","path_regex":"^(?:/tagmanager/v2/accounts/containers:lookup)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.lookup"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/destinations","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destinations)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.destinations.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/destinations/{destinationsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destinations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.destinations.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/version_headers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/version_headers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.version_headers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/version_headers:latest","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/version_headers:latest)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.version_headers.latest"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions:live","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions:live)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.live"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config/{gtag_configId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/status","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/status)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.getStatus"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/transformations","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transformations)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.transformations.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/transformations/{transformationsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transformations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.transformations.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.get"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}:snippet","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::snippet)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.snippet"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.list"},{"hostname":"tagmanager.googleapis.com","http_method":"GET","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions/{user_permissionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.get"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}/publish","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.publish"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}/restore","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restore)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.restore"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}/undelete","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/undelete)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.undelete"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v1/accounts/{accountId}/permissions","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/destinations:link","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/destinations:link)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.destinations.link"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}:reauthorize","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reauthorize)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.reauthorize"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}:publish","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publish)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.publish"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}:set_latest","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::set_latest)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.set_latest"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}:undelete","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.undelete"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/built_in_variables:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/built_in_variables:revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.built_in_variables.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}:entities","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::entities)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.entities"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}:move_entities_to_folder","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move_entities_to_folder)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.move_entities_to_folder"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/transformations","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transformations)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.transformations.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/transformations/{transformationsId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transformations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.transformations.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.create"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}:revert","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::revert)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.revert"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:create_version","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::create_version)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.create_version"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:quick_preview","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::quick_preview)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.quick_preview"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:resolve_conflict","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resolve_conflict)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.resolve_conflict"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}:sync","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::sync)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.sync"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}:combine","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::combine)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.combine"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}:move_tag_id","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::move_tag_id)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.move_tag_id"},{"hostname":"tagmanager.googleapis.com","http_method":"POST","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions)$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.create"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.folders.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/move_folders/{folderId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move_folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.move_folders.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/reauthorize_environments/{environmentId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reauthorize_environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.reauthorize_environments.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/tags/{tagId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.tags.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/triggers/{triggerId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.triggers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/variables/{variableId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.variables.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/containers/{containerId}/versions/{containerVersionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v1/accounts/{accountId}/permissions/{permissionId}","path_regex":"^(?:/tagmanager/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.permissions.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/environments/{environmentsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.environments.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/versions/{versionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.versions.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/clients/{clientsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.clients.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/folders/{foldersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/folders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.folders.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/gtag_config/{gtag_configId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/gtag_config/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.gtag_config.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/tags/{tagsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.tags.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/templates/{templatesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.templates.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/transformations/{transformationsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/transformations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.transformations.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/triggers/{triggersId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/triggers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.triggers.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/variables/{variablesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/variables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.variables.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/containers/{containersId}/workspaces/{workspacesId}/zones/{zonesId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/containers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workspaces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.containers.workspaces.zones.update"},{"hostname":"tagmanager.googleapis.com","http_method":"PUT","path_template":"/tagmanager/v2/accounts/{accountsId}/user_permissions/{user_permissionsId}","path_regex":"^(?:/tagmanager/v2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/user_permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tagmanager","resource_name":"tagmanager.accounts.user_permissions.update"},{"hostname":"tasks.googleapis.com","http_method":"DELETE","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.delete"},{"hostname":"tasks.googleapis.com","http_method":"DELETE","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.delete"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/lists/{tasklist}/tasks","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.tasks","resource_name":"tasks.tasks.list"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.get"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/users/@me/lists","path_regex":"^(?:/tasks/v1/users/@me/lists)$","service_name":"google.tasks","resource_name":"tasks.tasklists.list"},{"hostname":"tasks.googleapis.com","http_method":"GET","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.get"},{"hostname":"tasks.googleapis.com","http_method":"PATCH","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.patch"},{"hostname":"tasks.googleapis.com","http_method":"PATCH","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.patch"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/lists/{tasklist}/clear","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clear)$","service_name":"google.tasks","resource_name":"tasks.tasks.clear"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/lists/{tasklist}/tasks","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.tasks","resource_name":"tasks.tasks.insert"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}/move","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.tasks","resource_name":"tasks.tasks.move"},{"hostname":"tasks.googleapis.com","http_method":"POST","path_template":"/tasks/v1/users/@me/lists","path_regex":"^(?:/tasks/v1/users/@me/lists)$","service_name":"google.tasks","resource_name":"tasks.tasklists.insert"},{"hostname":"tasks.googleapis.com","http_method":"PUT","path_template":"/tasks/v1/lists/{tasklist}/tasks/{task}","path_regex":"^(?:/tasks/v1/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasks.update"},{"hostname":"tasks.googleapis.com","http_method":"PUT","path_template":"/tasks/v1/users/@me/lists/{tasklist}","path_regex":"^(?:/tasks/v1/users/@me/lists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tasks","resource_name":"tasks.tasklists.update"},{"hostname":"testing.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectId}/testMatrices/{testMatrixId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testMatrices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.testing","resource_name":"testing.projects.testMatrices.get"},{"hostname":"testing.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/deviceSessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceSessions)$","service_name":"google.testing","resource_name":"testing.projects.deviceSessions.list"},{"hostname":"testing.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/deviceSessions/{deviceSessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceSessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.testing","resource_name":"testing.projects.deviceSessions.get"},{"hostname":"testing.googleapis.com","http_method":"GET","path_template":"/v1/testEnvironmentCatalog/{environmentType}","path_regex":"^(?:/v1/testEnvironmentCatalog/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.testing","resource_name":"testing.testEnvironmentCatalog.get"},{"hostname":"testing.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/deviceSessions/{deviceSessionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceSessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.testing","resource_name":"testing.projects.deviceSessions.patch"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/applicationDetailService/getApkDetails","path_regex":"^(?:/v1/applicationDetailService/getApkDetails)$","service_name":"google.testing","resource_name":"testing.applicationDetailService.getApkDetails"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/testMatrices","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testMatrices)$","service_name":"google.testing","resource_name":"testing.projects.testMatrices.create"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectId}/testMatrices/{testMatrixId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testMatrices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.testing","resource_name":"testing.projects.testMatrices.cancel"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/deviceSessions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceSessions)$","service_name":"google.testing","resource_name":"testing.projects.deviceSessions.create"},{"hostname":"testing.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/deviceSessions/{deviceSessionsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deviceSessions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.testing","resource_name":"testing.projects.deviceSessions.cancel"},{"hostname":"texttospeech.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.texttospeech","resource_name":"texttospeech.operations.delete"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.list"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.get"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1/voices","path_regex":"^(?:/v1/voices)$","service_name":"google.texttospeech","resource_name":"texttospeech.voices.list"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.list"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.operations.get"},{"hostname":"texttospeech.googleapis.com","http_method":"GET","path_template":"/v1beta1/voices","path_regex":"^(?:/v1beta1/voices)$","service_name":"google.texttospeech","resource_name":"texttospeech.voices.list"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.texttospeech","resource_name":"texttospeech.operations.cancel"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}:synthesizeLongAudio","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::synthesizeLongAudio)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.synthesizeLongAudio"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1/text:synthesize","path_regex":"^(?:/v1/text:synthesize)$","service_name":"google.texttospeech","resource_name":"texttospeech.text.synthesize"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}:synthesizeLongAudio","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::synthesizeLongAudio)$","service_name":"google.texttospeech","resource_name":"texttospeech.projects.locations.synthesizeLongAudio"},{"hostname":"texttospeech.googleapis.com","http_method":"POST","path_template":"/v1beta1/text:synthesize","path_regex":"^(?:/v1beta1/text:synthesize)$","service_name":"google.texttospeech","resource_name":"texttospeech.text.synthesize"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/clusters","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.clusters.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/clusters/{clusterId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.clusters.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/environments","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.environments.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/environments/{environmentId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/environments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.environments.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfMetricsSummary","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfMetricsSummary)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.getPerfMetricsSummary"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries/{sampleSeriesId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries/{sampleSeriesId}/samples","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/samples)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.samples.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/testCases","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.testCases.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/testCases/{testCaseId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testCases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.testCases.get"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/thumbnails","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/thumbnails)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.thumbnails.list"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectId}/settings","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/settings)$","service_name":"google.toolresults","resource_name":"toolresults.projects.getSettings"},{"hostname":"toolresults.googleapis.com","http_method":"GET","path_template":"/toolresults/v1beta3/projects/{projectsId}/histories/{historiesId}/executions/{executionsId}/steps/{stepsId}:accessibilityClusters","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::accessibilityClusters)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.accessibilityClusters"},{"hostname":"toolresults.googleapis.com","http_method":"PATCH","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.patch"},{"hostname":"toolresults.googleapis.com","http_method":"PATCH","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.patch"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfMetricsSummary","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfMetricsSummary)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfMetricsSummary.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.create"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}/perfSampleSeries/{sampleSeriesId}/samples:batchCreate","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/perfSampleSeries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/samples:batchCreate)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.perfSampleSeries.samples.batchCreate"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}/histories/{historyId}/executions/{executionId}/steps/{stepId}:publishXunitXmlFiles","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/histories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/steps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::publishXunitXmlFiles)$","service_name":"google.toolresults","resource_name":"toolresults.projects.histories.executions.steps.publishXunitXmlFiles"},{"hostname":"toolresults.googleapis.com","http_method":"POST","path_template":"/toolresults/v1beta3/projects/{projectId}:initializeSettings","path_regex":"^(?:/toolresults/v1beta3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::initializeSettings)$","service_name":"google.toolresults","resource_name":"toolresults.projects.initializeSettings"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.delete"},{"hostname":"tpu.googleapis.com","http_method":"DELETE","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.delete"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions/{tensorflowVersionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/tensorflowVersions/{tensorflowVersionsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tensorflowVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.tensorflowVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queuedResources","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/runtimeVersions","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/runtimeVersions/{runtimeVersionsId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/acceleratorTypes/{acceleratorTypesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acceleratorTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.acceleratorTypes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.get"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/reservations","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reservations)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.reservations.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/runtimeVersions","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.list"},{"hostname":"tpu.googleapis.com","http_method":"GET","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/runtimeVersions/{runtimeVersionsId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/runtimeVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.runtimeVersions.get"},{"hostname":"tpu.googleapis.com","http_method":"PATCH","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.patch"},{"hostname":"tpu.googleapis.com","http_method":"PATCH","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.patch"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:reimage","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reimage)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.reimage"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:reimage","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reimage)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.reimage"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:getGuestAttributes","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getGuestAttributes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.getGuestAttributes"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queuedResources","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}:reset","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.reset"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/locations/{locationsId}:generateServiceIdentity","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateServiceIdentity)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.generateServiceIdentity"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:getGuestAttributes","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getGuestAttributes)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.getGuestAttributes"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:simulateMaintenanceEvent","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::simulateMaintenanceEvent)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.simulateMaintenanceEvent"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:start","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.start"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/nodes/{nodesId}:stop","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.nodes.stop"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.operations.cancel"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.create"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}/queuedResources/{queuedResourcesId}:reset","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/queuedResources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reset)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.queuedResources.reset"},{"hostname":"tpu.googleapis.com","http_method":"POST","path_template":"/v2alpha1/projects/{projectsId}/locations/{locationsId}:generateServiceIdentity","path_regex":"^(?:/v2alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateServiceIdentity)$","service_name":"google.tpu","resource_name":"tpu.projects.locations.generateServiceIdentity"},{"hostname":"tracing.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/traces","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces)$","service_name":"google.tracing","resource_name":"tracing.projects.traces.list"},{"hostname":"tracing.googleapis.com","http_method":"GET","path_template":"/v2/projects/{projectsId}/traces/{tracesId}:listSpans","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listSpans)$","service_name":"google.tracing","resource_name":"tracing.projects.traces.listSpans"},{"hostname":"tracing.googleapis.com","http_method":"POST","path_template":"/v2/projects/{projectsId}/traces:batchWrite","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces:batchWrite)$","service_name":"google.tracing","resource_name":"tracing.projects.traces.batchWrite"},{"hostname":"tracing.googleapis.com","http_method":"PUT","path_template":"/v2/projects/{projectsId}/traces/{tracesId}/spans/{spansId}","path_regex":"^(?:/v2/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/traces/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spans/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.tracing","resource_name":"tracing.projects.traces.spans.create"},{"hostname":"trafficdirector.googleapis.com","http_method":"POST","path_template":"/v2/discovery:client_status","path_regex":"^(?:/v2/discovery:client_status)$","service_name":"google.trafficdirector","resource_name":"trafficdirector.discovery.client_status"},{"hostname":"trafficdirector.googleapis.com","http_method":"POST","path_template":"/v3/discovery:client_status","path_regex":"^(?:/v3/discovery:client_status)$","service_name":"google.trafficdirector","resource_name":"trafficdirector.discovery.client_status"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.delete"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.delete"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.delete"},{"hostname":"transcoder.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.delete"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.get"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.get"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates/{jobTemplatesId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.get"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.list"},{"hostname":"transcoder.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs/{jobsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.get"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.create"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.create"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobTemplates","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobTemplates)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobTemplates.create"},{"hostname":"transcoder.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/jobs","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/jobs)$","service_name":"google.transcoder","resource_name":"transcoder.projects.locations.jobs.create"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}/adaptiveMtFiles/{adaptiveMtFilesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.adaptiveMtFiles.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries/{glossaryEntriesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.models.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.delete"},{"hostname":"translation.googleapis.com","http_method":"DELETE","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.delete"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/language/translate/v2","path_regex":"^(?:/language/translate/v2)$","service_name":"google.translate","resource_name":"language.translations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/language/translate/v2/detect","path_regex":"^(?:/language/translate/v2/detect)$","service_name":"google.translate","resource_name":"language.detections.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/language/translate/v2/languages","path_regex":"^(?:/language/translate/v2/languages)$","service_name":"google.translate","resource_name":"language.languages.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.translate","resource_name":"translate.projects.locations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets)$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}/adaptiveMtFiles","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtFiles)$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.adaptiveMtFiles.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}/adaptiveMtFiles/{adaptiveMtFilesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.adaptiveMtFiles.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}/adaptiveMtFiles/{adaptiveMtFilesId}/adaptiveMtSentences","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtFiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtSentences)$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.adaptiveMtFiles.adaptiveMtSentences.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}/adaptiveMtSentences","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtSentences)$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.adaptiveMtSentences.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}/examples","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/examples)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.examples.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries/{glossaryEntriesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.translate","resource_name":"translate.projects.locations.models.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models/{modelsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.models.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/supportedLanguages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.locations.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3/projects/{projectsId}/supportedLanguages","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.translate","resource_name":"translate.projects.locations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.list"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.get"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/supportedLanguages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.locations.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"GET","path_template":"/v3beta1/projects/{projectsId}/supportedLanguages","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/supportedLanguages)$","service_name":"google.translate","resource_name":"translate.projects.getSupportedLanguages"},{"hostname":"translation.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.patch"},{"hostname":"translation.googleapis.com","http_method":"PATCH","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries/{glossaryEntriesId}","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.patch"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/language/translate/v2","path_regex":"^(?:/language/translate/v2)$","service_name":"google.translate","resource_name":"language.translations.translate"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/language/translate/v2/detect","path_regex":"^(?:/language/translate/v2/detect)$","service_name":"google.translate","resource_name":"language.detections.detect"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets)$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/adaptiveMtDatasets/{adaptiveMtDatasetsId}:importAdaptiveMtFile","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adaptiveMtDatasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importAdaptiveMtFile)$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtDatasets.importAdaptiveMtFile"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:exportData","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportData)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.exportData"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/datasets/{datasetsId}:importData","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datasets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::importData)$","service_name":"google.translate","resource_name":"translate.projects.locations.datasets.importData"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/glossaries/{glossariesId}/glossaryEntries","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaryEntries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.glossaryEntries.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/models","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/models)$","service_name":"google.translate","resource_name":"translate.projects.locations.models.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.cancel"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.wait"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:adaptiveMtTranslate","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::adaptiveMtTranslate)$","service_name":"google.translate","resource_name":"translate.projects.locations.adaptiveMtTranslate"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:batchTranslateDocument","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:batchTranslateText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:detectLanguage","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.locations.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:romanizeText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::romanizeText)$","service_name":"google.translate","resource_name":"translate.projects.locations.romanizeText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:translateDocument","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}/locations/{locationsId}:translateText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:detectLanguage","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:romanizeText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::romanizeText)$","service_name":"google.translate","resource_name":"translate.projects.romanizeText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3/projects/{projectsId}:translateText","path_regex":"^(?:/v3/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.translateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/glossaries","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/glossaries)$","service_name":"google.translate","resource_name":"translate.projects.locations.glossaries.create"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.cancel"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:wait","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::wait)$","service_name":"google.translate","resource_name":"translate.projects.locations.operations.wait"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:batchTranslateDocument","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:batchTranslateText","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::batchTranslateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.batchTranslateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:detectLanguage","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.locations.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:translateDocument","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateDocument)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateDocument"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}/locations/{locationsId}:translateText","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.locations.translateText"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}:detectLanguage","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::detectLanguage)$","service_name":"google.translate","resource_name":"translate.projects.detectLanguage"},{"hostname":"translation.googleapis.com","http_method":"POST","path_template":"/v3beta1/projects/{projectsId}:translateText","path_regex":"^(?:/v3beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::translateText)$","service_name":"google.translate","resource_name":"translate.projects.translateText"},{"hostname":"travelimpactmodel.googleapis.com","http_method":"POST","path_template":"/v1/flights:computeFlightEmissions","path_regex":"^(?:/v1/flights:computeFlightEmissions)$","service_name":"google.travelimpactmodel","resource_name":"travelimpactmodel.flights.computeFlightEmissions"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/exports/{exportId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.exports.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/holds/{holdId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/holds/{holdId}/accounts/{accountId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.accounts.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/matters/{matterId}/savedQueries/{savedQueryId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.delete"},{"hostname":"vault.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.operations.delete"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters","path_regex":"^(?:/v1/matters)$","service_name":"google.vault","resource_name":"vault.matters.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/exports","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports)$","service_name":"google.vault","resource_name":"vault.matters.exports.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/exports/{exportId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.exports.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/holds","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds)$","service_name":"google.vault","resource_name":"vault.matters.holds.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/holds/{holdId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/holds/{holdId}/accounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.accounts.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/savedQueries","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/matters/{matterId}/savedQueries/{savedQueryId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.get"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.vault","resource_name":"vault.operations.list"},{"hostname":"vault.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.operations.get"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters","path_regex":"^(?:/v1/matters)$","service_name":"google.vault","resource_name":"vault.matters.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/exports","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/exports)$","service_name":"google.vault","resource_name":"vault.matters.exports.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds)$","service_name":"google.vault","resource_name":"vault.matters.holds.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds/{holdId}/accounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.accounts.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds/{holdId}:addHeldAccounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addHeldAccounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.addHeldAccounts"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/holds/{holdId}:removeHeldAccounts","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeHeldAccounts)$","service_name":"google.vault","resource_name":"vault.matters.holds.removeHeldAccounts"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}/savedQueries","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedQueries)$","service_name":"google.vault","resource_name":"vault.matters.savedQueries.create"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:addPermissions","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addPermissions)$","service_name":"google.vault","resource_name":"vault.matters.addPermissions"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:close","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::close)$","service_name":"google.vault","resource_name":"vault.matters.close"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:count","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::count)$","service_name":"google.vault","resource_name":"vault.matters.count"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:removePermissions","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removePermissions)$","service_name":"google.vault","resource_name":"vault.matters.removePermissions"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:reopen","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reopen)$","service_name":"google.vault","resource_name":"vault.matters.reopen"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/matters/{matterId}:undelete","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.vault","resource_name":"vault.matters.undelete"},{"hostname":"vault.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vault","resource_name":"vault.operations.cancel"},{"hostname":"vault.googleapis.com","http_method":"PUT","path_template":"/v1/matters/{matterId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.update"},{"hostname":"vault.googleapis.com","http_method":"PUT","path_template":"/v1/matters/{matterId}/holds/{holdId}","path_regex":"^(?:/v1/matters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/holds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vault","resource_name":"vault.matters.holds.update"},{"hostname":"vectortile.googleapis.com","http_method":"GET","path_template":"/v1/featuretiles/{featuretilesId}","path_regex":"^(?:/v1/featuretiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vectortile","resource_name":"vectortile.featuretiles.get"},{"hostname":"vectortile.googleapis.com","http_method":"GET","path_template":"/v1/terraintiles/{terraintilesId}","path_regex":"^(?:/v1/terraintiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vectortile","resource_name":"vectortile.terraintiles.get"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v1/challenge","path_regex":"^(?:/v1/challenge)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.create"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v1/challenge:verify","path_regex":"^(?:/v1/challenge:verify)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.verify"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v2/challenge:generate","path_regex":"^(?:/v2/challenge:generate)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.generate"},{"hostname":"verifiedaccess.googleapis.com","http_method":"POST","path_template":"/v2/challenge:verify","path_regex":"^(?:/v2/challenge:verify)$","service_name":"google.verifiedaccess","resource_name":"verifiedaccess.challenge.verify"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.list"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms/{platformsId}/channels","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.channels.list"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms/{platformsId}/channels/{channelsId}/versions","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.channels.versions.list"},{"hostname":"versionhistory.googleapis.com","http_method":"GET","path_template":"/v1/{v1Id}/platforms/{platformsId}/channels/{channelsId}/versions/{versionsId}/releases","path_regex":"^(?:/v1/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platforms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/channels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/versions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/releases)$","service_name":"google.versionhistory","resource_name":"versionhistory.platforms.channels.versions.releases.list"},{"hostname":"videointelligence.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.operations.projects.locations.operations.delete"},{"hostname":"videointelligence.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.delete"},{"hostname":"videointelligence.googleapis.com","http_method":"GET","path_template":"/v1/operations/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.operations.projects.locations.operations.get"},{"hostname":"videointelligence.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.list"},{"hostname":"videointelligence.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.get"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1/operations/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.videointelligence","resource_name":"videointelligence.operations.projects.locations.operations.cancel"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.videointelligence","resource_name":"videointelligence.projects.locations.operations.cancel"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1/videos:annotate","path_regex":"^(?:/v1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1beta2/videos:annotate","path_regex":"^(?:/v1beta2/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/videos:annotate","path_regex":"^(?:/v1p1beta1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/videos:annotate","path_regex":"^(?:/v1p2beta1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"videointelligence.googleapis.com","http_method":"POST","path_template":"/v1p3beta1/videos:annotate","path_regex":"^(?:/v1p3beta1/videos:annotate)$","service_name":"google.videointelligence","resource_name":"videointelligence.videos.annotate"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.operations.delete"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.delete"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.delete"},{"hostname":"vision.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages/{referenceImagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.delete"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.locations.operations.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/operations","path_regex":"^(?:/v1/operations)$","service_name":"google.vision","resource_name":"vision.operations.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.operations.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.operations.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}/products","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.products.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.list"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages/{referenceImagesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.get"},{"hostname":"vision.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.operations.get"},{"hostname":"vision.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.patch"},{"hostname":"vision.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vision","resource_name":"vision.projects.locations.products.patch"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/files:annotate","path_regex":"^(?:/v1/files:annotate)$","service_name":"google.vision","resource_name":"vision.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/files:asyncBatchAnnotate","path_regex":"^(?:/v1/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/images:annotate","path_regex":"^(?:/v1/images:annotate)$","service_name":"google.vision","resource_name":"vision.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/images:asyncBatchAnnotate","path_regex":"^(?:/v1/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/operations/{operationsId}:cancel","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vision","resource_name":"vision.operations.cancel"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/files:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/images:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/files:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/images:annotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.create"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}:addProduct","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addProduct)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.addProduct"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets/{productSetsId}:removeProduct","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeProduct)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.removeProduct"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/productSets:import","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/productSets:import)$","service_name":"google.vision","resource_name":"vision.projects.locations.productSets.import"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.create"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products/{productsId}/referenceImages","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/referenceImages)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.referenceImages.create"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/products:purge","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/products:purge)$","service_name":"google.vision","resource_name":"vision.projects.locations.products.purge"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/files:annotate","path_regex":"^(?:/v1p1beta1/files:annotate)$","service_name":"google.vision","resource_name":"vision.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/files:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/images:annotate","path_regex":"^(?:/v1p1beta1/images:annotate)$","service_name":"google.vision","resource_name":"vision.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/images:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/files:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/images:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/files:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/images:annotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p1beta1/projects/{projectsId}/locations/{locationsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/files:annotate","path_regex":"^(?:/v1p2beta1/files:annotate)$","service_name":"google.vision","resource_name":"vision.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/files:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/images:annotate","path_regex":"^(?:/v1p2beta1/images:annotate)$","service_name":"google.vision","resource_name":"vision.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/images:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/files:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/images:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.images.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/files:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/files:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.files.asyncBatchAnnotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/images:annotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:annotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.annotate"},{"hostname":"vision.googleapis.com","http_method":"POST","path_template":"/v1p2beta1/projects/{projectsId}/locations/{locationsId}/images:asyncBatchAnnotate","path_regex":"^(?:/v1p2beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/images:asyncBatchAnnotate)$","service_name":"google.vision","resource_name":"vision.projects.locations.images.asyncBatchAnnotate"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"DELETE","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.delete"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageImports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}/imageImportJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImportJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.imageImportJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}/imageImportJobs/{imageImportJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.imageImportJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles/{replicationCyclesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}:fetchInventory","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchInventory)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.fetchInventory"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/imageImports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}/imageImportJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImportJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.imageImportJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}/imageImportJobs/{imageImportJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.imageImportJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/replicationCycles/{replicationCyclesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicationCycles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.replicationCycles.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports/{utilizationReportsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.get"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}:fetchInventory","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchInventory)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.fetchInventory"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.list"},{"hostname":"vmmigration.googleapis.com","http_method":"GET","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.get"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"PATCH","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects/{targetProjectsId}","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.patch"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:addGroupMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.addGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:removeGroupMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.removeGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageImports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}/imageImportJobs/{imageImportJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.imageImportJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}:upgradeAppliance","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgradeAppliance)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.upgradeAppliance"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/diskMigrationJobs/{diskMigrationJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskMigrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.diskMigrationJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/diskMigrationJobs/{diskMigrationJobsId}:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskMigrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.diskMigrationJobs.run"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:finalizeMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::finalizeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.finalizeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:pauseMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pauseMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.pauseMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:resumeMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resumeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.resumeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:startMigration","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.startMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:addGroupMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::addGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.addGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/groups/{groupsId}:removeGroupMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::removeGroupMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.groups.removeGroupMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/imageImports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/imageImports/{imageImportsId}/imageImportJobs/{imageImportJobsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/imageImportJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.imageImports.imageImportJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.operations.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/datacenterConnectors/{datacenterConnectorsId}:upgradeAppliance","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/datacenterConnectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::upgradeAppliance)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.datacenterConnectors.upgradeAppliance"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/diskMigrationJobs/{diskMigrationJobsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskMigrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.diskMigrationJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/diskMigrationJobs/{diskMigrationJobsId}:run","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/diskMigrationJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::run)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.diskMigrationJobs.run"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cloneJobs/{cloneJobsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cloneJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cloneJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}/cutoverJobs/{cutoverJobsId}:cancel","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cutoverJobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.cutoverJobs.cancel"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:finalizeMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::finalizeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.finalizeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:pauseMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::pauseMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.pauseMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:resumeMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resumeMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.resumeMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/migratingVms/{migratingVmsId}:startMigration","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/migratingVms/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::startMigration)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.migratingVms.startMigration"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/sources/{sourcesId}/utilizationReports","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sources/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/utilizationReports)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.sources.utilizationReports.create"},{"hostname":"vmmigration.googleapis.com","http_method":"POST","path_template":"/v1alpha1/projects/{projectsId}/locations/{locationsId}/targetProjects","path_regex":"^(?:/v1alpha1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetProjects)$","service_name":"google.vmmigration","resource_name":"vmmigration.projects.locations.targetProjects.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPeerings/{networkPeeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPeerings.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}/externalAccessRules/{externalAccessRulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccessRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.externalAccessRules.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.operations.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/externalAddresses/{externalAddressesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.externalAddresses.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/loggingServers/{loggingServersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loggingServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.loggingServers.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/managementDnsZoneBindings/{managementDnsZoneBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementDnsZoneBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.managementDnsZoneBindings.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateConnections.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareEngineNetworks/{vmwareEngineNetworksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareEngineNetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.vmwareEngineNetworks.delete"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsBindPermission","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsBindPermission)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.getDnsBindPermission"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPeerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPeerings)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPeerings.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPeerings/{networkPeeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPeerings.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPeerings/{networkPeeringsId}/peeringRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeringRoutes)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPeerings.peeringRoutes.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}/externalAccessRules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccessRules)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.externalAccessRules.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}/externalAccessRules/{externalAccessRulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccessRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.externalAccessRules.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}:fetchExternalAddresses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::fetchExternalAddresses)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.fetchExternalAddresses"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodeTypes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.nodeTypes.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/nodeTypes/{nodeTypesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodeTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.nodeTypes.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.operations.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.operations.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}/nodes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.nodes.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}/nodes/{nodesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/nodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.nodes.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.getIamPolicy"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/dnsForwarding","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsForwarding)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.getDnsForwarding"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/externalAddresses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAddresses)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.externalAddresses.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/externalAddresses/{externalAddressesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.externalAddresses.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/hcxActivationKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hcxActivationKeys)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.hcxActivationKeys.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/hcxActivationKeys/{hcxActivationKeysId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hcxActivationKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.hcxActivationKeys.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/hcxActivationKeys/{hcxActivationKeysId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hcxActivationKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.hcxActivationKeys.getIamPolicy"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/loggingServers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loggingServers)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.loggingServers.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/loggingServers/{loggingServersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loggingServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.loggingServers.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/managementDnsZoneBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementDnsZoneBindings)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.managementDnsZoneBindings.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/managementDnsZoneBindings/{managementDnsZoneBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementDnsZoneBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.managementDnsZoneBindings.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/subnets","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnets)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.subnets.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/subnets/{subnetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.subnets.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.getIamPolicy"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:showNsxCredentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::showNsxCredentials)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.showNsxCredentials"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:showVcenterCredentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::showVcenterCredentials)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.showVcenterCredentials"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateConnections.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateConnections.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}/peeringRoutes","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/peeringRoutes)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateConnections.peeringRoutes.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareEngineNetworks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareEngineNetworks)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.vmwareEngineNetworks.list"},{"hostname":"vmwareengine.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareEngineNetworks/{vmwareEngineNetworksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareEngineNetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.vmwareEngineNetworks.get"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPeerings/{networkPeeringsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPeerings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPeerings.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}/externalAccessRules/{externalAccessRulesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccessRules/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.externalAccessRules.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/dnsForwarding","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsForwarding)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.updateDnsForwarding"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/externalAddresses/{externalAddressesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAddresses/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.externalAddresses.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/loggingServers/{loggingServersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loggingServers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.loggingServers.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/managementDnsZoneBindings/{managementDnsZoneBindingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementDnsZoneBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.managementDnsZoneBindings.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/subnets/{subnetsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subnets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.subnets.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections/{privateConnectionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateConnections.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareEngineNetworks/{vmwareEngineNetworksId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareEngineNetworks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.vmwareEngineNetworks.patch"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsBindPermission:grant","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsBindPermission:grant)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.dnsBindPermission.grant"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/dnsBindPermission:revoke","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dnsBindPermission:revoke)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.dnsBindPermission.revoke"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPeerings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPeerings)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPeerings.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/networkPolicies/{networkPoliciesId}/externalAccessRules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/networkPolicies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAccessRules)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.networkPolicies.externalAccessRules.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.setIamPolicy"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/clusters/{clustersId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.clusters.testIamPermissions"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/externalAddresses","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/externalAddresses)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.externalAddresses.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/hcxActivationKeys","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hcxActivationKeys)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.hcxActivationKeys.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/hcxActivationKeys/{hcxActivationKeysId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hcxActivationKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.hcxActivationKeys.setIamPolicy"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/hcxActivationKeys/{hcxActivationKeysId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hcxActivationKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.hcxActivationKeys.testIamPermissions"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/loggingServers","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/loggingServers)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.loggingServers.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/managementDnsZoneBindings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementDnsZoneBindings)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.managementDnsZoneBindings.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}/managementDnsZoneBindings/{managementDnsZoneBindingsId}:repair","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/managementDnsZoneBindings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::repair)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.managementDnsZoneBindings.repair"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:resetNsxCredentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetNsxCredentials)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.resetNsxCredentials"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:resetVcenterCredentials","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::resetVcenterCredentials)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.resetVcenterCredentials"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.setIamPolicy"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.testIamPermissions"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateClouds/{privateCloudsId}:undelete","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateClouds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::undelete)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateClouds.undelete"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/privateConnections","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/privateConnections)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.privateConnections.create"},{"hostname":"vmwareengine.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/vmwareEngineNetworks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/vmwareEngineNetworks)$","service_name":"google.vmwareengine","resource_name":"vmwareengine.projects.locations.vmwareEngineNetworks.create"},{"hostname":"vpcaccess.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.delete"},{"hostname":"vpcaccess.googleapis.com","http_method":"DELETE","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.delete"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.list"},{"hostname":"vpcaccess.googleapis.com","http_method":"GET","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.operations.get"},{"hostname":"vpcaccess.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.patch"},{"hostname":"vpcaccess.googleapis.com","http_method":"PATCH","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors/{connectorsId}","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.patch"},{"hostname":"vpcaccess.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.create"},{"hostname":"vpcaccess.googleapis.com","http_method":"POST","path_template":"/v1beta1/projects/{projectsId}/locations/{locationsId}/connectors","path_regex":"^(?:/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectors)$","service_name":"google.vpcaccess","resource_name":"vpcaccess.projects.locations.connectors.create"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/eventTicketClass","path_regex":"^(?:/walletobjects/v1/eventTicketClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketclass.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/eventTicketClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/eventTicketClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketclass.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/eventTicketObject","path_regex":"^(?:/walletobjects/v1/eventTicketObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketobject.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/eventTicketObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/eventTicketObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketobject.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/flightClass","path_regex":"^(?:/walletobjects/v1/flightClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.flightclass.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/flightClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/flightClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.flightclass.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/flightObject","path_regex":"^(?:/walletobjects/v1/flightObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.flightobject.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/flightObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/flightObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.flightobject.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/genericClass","path_regex":"^(?:/walletobjects/v1/genericClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.genericclass.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/genericClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/genericClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.genericclass.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/genericObject","path_regex":"^(?:/walletobjects/v1/genericObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.genericobject.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/genericObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/genericObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.genericobject.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/giftCardClass","path_regex":"^(?:/walletobjects/v1/giftCardClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardclass.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/giftCardClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/giftCardClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardclass.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/giftCardObject","path_regex":"^(?:/walletobjects/v1/giftCardObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardobject.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/giftCardObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/giftCardObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardobject.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/issuer","path_regex":"^(?:/walletobjects/v1/issuer)$","service_name":"google.walletobjects","resource_name":"walletobjects.issuer.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/issuer/{resourceId}","path_regex":"^(?:/walletobjects/v1/issuer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.issuer.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/loyaltyClass","path_regex":"^(?:/walletobjects/v1/loyaltyClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyclass.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/loyaltyClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/loyaltyClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyclass.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/loyaltyObject","path_regex":"^(?:/walletobjects/v1/loyaltyObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyobject.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/loyaltyObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/loyaltyObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyobject.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/offerClass","path_regex":"^(?:/walletobjects/v1/offerClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.offerclass.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/offerClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/offerClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.offerclass.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/offerObject","path_regex":"^(?:/walletobjects/v1/offerObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.offerobject.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/offerObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/offerObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.offerobject.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/permissions/{resourceId}","path_regex":"^(?:/walletobjects/v1/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.permissions.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/transitClass","path_regex":"^(?:/walletobjects/v1/transitClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.transitclass.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/transitClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/transitClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.transitclass.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/transitObject","path_regex":"^(?:/walletobjects/v1/transitObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.transitobject.list"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/transitObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/transitObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.transitobject.get"},{"hostname":"walletobjects.googleapis.com","http_method":"GET","path_template":"/walletobjects/v1/transitObject/{resourceId}/downloadRotatingBarcodeValues","path_regex":"^(?:/walletobjects/v1/transitObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/downloadRotatingBarcodeValues)$","service_name":"google.walletobjects","resource_name":"walletobjects.media.download"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/eventTicketClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/eventTicketClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketclass.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/eventTicketObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/eventTicketObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketobject.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/flightClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/flightClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.flightclass.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/flightObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/flightObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.flightobject.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/genericClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/genericClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.genericclass.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/genericObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/genericObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.genericobject.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/giftCardClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/giftCardClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardclass.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/giftCardObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/giftCardObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardobject.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/issuer/{resourceId}","path_regex":"^(?:/walletobjects/v1/issuer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.issuer.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/loyaltyClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/loyaltyClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyclass.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/loyaltyObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/loyaltyObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyobject.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/offerClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/offerClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.offerclass.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/offerObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/offerObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.offerobject.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/transitClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/transitClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.transitclass.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"PATCH","path_template":"/walletobjects/v1/transitObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/transitObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.transitobject.patch"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/eventTicketClass","path_regex":"^(?:/walletobjects/v1/eventTicketClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketclass.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/eventTicketClass/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/eventTicketClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketclass.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/eventTicketObject","path_regex":"^(?:/walletobjects/v1/eventTicketObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketobject.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/eventTicketObject/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/eventTicketObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketobject.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/eventTicketObject/{resourceId}/modifyLinkedOfferObjects","path_regex":"^(?:/walletobjects/v1/eventTicketObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modifyLinkedOfferObjects)$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketobject.modifylinkedofferobjects"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/flightClass","path_regex":"^(?:/walletobjects/v1/flightClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.flightclass.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/flightClass/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/flightClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.flightclass.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/flightObject","path_regex":"^(?:/walletobjects/v1/flightObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.flightobject.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/flightObject/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/flightObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.flightobject.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/genericClass","path_regex":"^(?:/walletobjects/v1/genericClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.genericclass.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/genericClass/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/genericClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.genericclass.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/genericObject","path_regex":"^(?:/walletobjects/v1/genericObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.genericobject.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/genericObject/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/genericObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.genericobject.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/giftCardClass","path_regex":"^(?:/walletobjects/v1/giftCardClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardclass.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/giftCardClass/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/giftCardClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardclass.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/giftCardObject","path_regex":"^(?:/walletobjects/v1/giftCardObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardobject.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/giftCardObject/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/giftCardObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardobject.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/issuer","path_regex":"^(?:/walletobjects/v1/issuer)$","service_name":"google.walletobjects","resource_name":"walletobjects.issuer.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/jwt","path_regex":"^(?:/walletobjects/v1/jwt)$","service_name":"google.walletobjects","resource_name":"walletobjects.jwt.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/loyaltyClass","path_regex":"^(?:/walletobjects/v1/loyaltyClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyclass.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/loyaltyClass/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/loyaltyClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyclass.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/loyaltyObject","path_regex":"^(?:/walletobjects/v1/loyaltyObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyobject.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/loyaltyObject/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/loyaltyObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyobject.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/loyaltyObject/{resourceId}/modifyLinkedOfferObjects","path_regex":"^(?:/walletobjects/v1/loyaltyObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modifyLinkedOfferObjects)$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyobject.modifylinkedofferobjects"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/offerClass","path_regex":"^(?:/walletobjects/v1/offerClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.offerclass.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/offerClass/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/offerClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.offerclass.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/offerObject","path_regex":"^(?:/walletobjects/v1/offerObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.offerobject.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/offerObject/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/offerObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.offerobject.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/smartTap","path_regex":"^(?:/walletobjects/v1/smartTap)$","service_name":"google.walletobjects","resource_name":"walletobjects.smarttap.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/transitClass","path_regex":"^(?:/walletobjects/v1/transitClass)$","service_name":"google.walletobjects","resource_name":"walletobjects.transitclass.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/transitClass/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/transitClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.transitclass.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/transitObject","path_regex":"^(?:/walletobjects/v1/transitObject)$","service_name":"google.walletobjects","resource_name":"walletobjects.transitobject.insert"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/transitObject/{resourceId}/addMessage","path_regex":"^(?:/walletobjects/v1/transitObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addMessage)$","service_name":"google.walletobjects","resource_name":"walletobjects.transitobject.addmessage"},{"hostname":"walletobjects.googleapis.com","http_method":"POST","path_template":"/walletobjects/v1/transitObject/{resourceId}/uploadRotatingBarcodeValues","path_regex":"^(?:/walletobjects/v1/transitObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/uploadRotatingBarcodeValues)$","service_name":"google.walletobjects","resource_name":"walletobjects.media.upload"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/eventTicketClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/eventTicketClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketclass.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/eventTicketObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/eventTicketObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.eventticketobject.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/flightClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/flightClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.flightclass.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/flightObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/flightObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.flightobject.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/genericClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/genericClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.genericclass.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/genericObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/genericObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.genericobject.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/giftCardClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/giftCardClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardclass.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/giftCardObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/giftCardObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.giftcardobject.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/issuer/{resourceId}","path_regex":"^(?:/walletobjects/v1/issuer/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.issuer.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/loyaltyClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/loyaltyClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyclass.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/loyaltyObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/loyaltyObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.loyaltyobject.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/offerClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/offerClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.offerclass.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/offerObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/offerObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.offerobject.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/permissions/{resourceId}","path_regex":"^(?:/walletobjects/v1/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.permissions.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/transitClass/{resourceId}","path_regex":"^(?:/walletobjects/v1/transitClass/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.transitclass.update"},{"hostname":"walletobjects.googleapis.com","http_method":"PUT","path_template":"/walletobjects/v1/transitObject/{resourceId}","path_regex":"^(?:/walletobjects/v1/transitObject/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.walletobjects","resource_name":"walletobjects.transitobject.update"},{"hostname":"webfonts.googleapis.com","http_method":"GET","path_template":"/v1/webfonts","path_regex":"^(?:/v1/webfonts)$","service_name":"google.webfonts","resource_name":"webfonts.webfonts.list"},{"hostname":"webrisk.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.delete"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/hashes:search","path_regex":"^(?:/v1/hashes:search)$","service_name":"google.webrisk","resource_name":"webrisk.hashes.search"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.list"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.get"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/threatLists:computeDiff","path_regex":"^(?:/v1/threatLists:computeDiff)$","service_name":"google.webrisk","resource_name":"webrisk.threatLists.computeDiff"},{"hostname":"webrisk.googleapis.com","http_method":"GET","path_template":"/v1/uris:search","path_regex":"^(?:/v1/uris:search)$","service_name":"google.webrisk","resource_name":"webrisk.uris.search"},{"hostname":"webrisk.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.webrisk","resource_name":"webrisk.projects.operations.cancel"},{"hostname":"webrisk.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/submissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/submissions)$","service_name":"google.webrisk","resource_name":"webrisk.projects.submissions.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.delete"},{"hostname":"websecurityscanner.googleapis.com","http_method":"DELETE","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.delete"},{"hostname":"websecurityscanner.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.delete"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/crawledUrls","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crawledUrls)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.crawledUrls.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findingTypeStats","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findingTypeStats)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findingTypeStats.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings/{findingsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/crawledUrls","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crawledUrls)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.crawledUrls.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findingTypeStats","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findingTypeStats)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findingTypeStats.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings/{findingsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/crawledUrls","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/crawledUrls)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.crawledUrls.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findingTypeStats","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findingTypeStats)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findingTypeStats.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.list"},{"hostname":"websecurityscanner.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}/findings/{findingsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/findings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.findings.get"},{"hostname":"websecurityscanner.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.patch"},{"hostname":"websecurityscanner.googleapis.com","http_method":"PATCH","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.patch"},{"hostname":"websecurityscanner.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.patch"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.stop"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/scanConfigs/{scanConfigsId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.start"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}:stop","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.stop"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1alpha/projects/{projectsId}/scanConfigs/{scanConfigsId}:start","path_regex":"^(?:/v1alpha/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.start"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/scanConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.create"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}/scanRuns/{scanRunsId}:stop","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanRuns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.scanRuns.stop"},{"hostname":"websecurityscanner.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/scanConfigs/{scanConfigsId}:start","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scanConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.websecurityscanner","resource_name":"websecurityscanner.projects.scanConfigs.start"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.list"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.get"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}/callbacks","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/callbacks)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.callbacks.list"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}/stepEntries","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stepEntries)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.stepEntries.list"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}/stepEntries/{stepEntriesId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stepEntries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.stepEntries.get"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}:exportData","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::exportData)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.exportData"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.list"},{"hostname":"workflowexecutions.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.get"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.create"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.cancel"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}:triggerPubsubExecution","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::triggerPubsubExecution)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.triggerPubsubExecution"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.create"},{"hostname":"workflowexecutions.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}/executions/{executionsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workflowexecutions","resource_name":"workflowexecutions.projects.locations.workflows.executions.cancel"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.delete"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.delete"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.delete"},{"hostname":"workflows.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.delete"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}:listRevisions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::listRevisions)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.listRevisions"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.operations.get"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.list"},{"hostname":"workflows.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.get"},{"hostname":"workflows.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.patch"},{"hostname":"workflows.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows/{workflowsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.patch"},{"hostname":"workflows.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.create"},{"hostname":"workflows.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workflows","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workflows)$","service_name":"google.workflows","resource_name":"workflows.projects.locations.workflows.create"},{"hostname":"workloadmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.delete"},{"hostname":"workloadmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.delete"},{"hostname":"workloadmanager.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.delete"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions/{executionsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions/{executionsId}/results","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.results.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions/{executionsId}/scannedResources","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/scannedResources)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.scannedResources.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.get"},{"hostname":"workloadmanager.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/rules","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rules)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.rules.list"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.create"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/evaluations/{evaluationsId}/executions:run","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/evaluations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/executions:run)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.evaluations.executions.run"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/insights:writeInsight","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/insights:writeInsight)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.insights.writeInsight"},{"hostname":"workloadmanager.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workloadmanager","resource_name":"workloadmanager.projects.locations.operations.cancel"},{"hostname":"workspaceevents.googleapis.com","http_method":"DELETE","path_template":"/v1/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workspaceevents","resource_name":"workspaceevents.subscriptions.delete"},{"hostname":"workspaceevents.googleapis.com","http_method":"GET","path_template":"/v1/operations/{operationsId}","path_regex":"^(?:/v1/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workspaceevents","resource_name":"workspaceevents.operations.get"},{"hostname":"workspaceevents.googleapis.com","http_method":"GET","path_template":"/v1/subscriptions","path_regex":"^(?:/v1/subscriptions)$","service_name":"google.workspaceevents","resource_name":"workspaceevents.subscriptions.list"},{"hostname":"workspaceevents.googleapis.com","http_method":"GET","path_template":"/v1/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workspaceevents","resource_name":"workspaceevents.subscriptions.get"},{"hostname":"workspaceevents.googleapis.com","http_method":"PATCH","path_template":"/v1/subscriptions/{subscriptionsId}","path_regex":"^(?:/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workspaceevents","resource_name":"workspaceevents.subscriptions.patch"},{"hostname":"workspaceevents.googleapis.com","http_method":"POST","path_template":"/v1/subscriptions","path_regex":"^(?:/v1/subscriptions)$","service_name":"google.workspaceevents","resource_name":"workspaceevents.subscriptions.create"},{"hostname":"workspaceevents.googleapis.com","http_method":"POST","path_template":"/v1/subscriptions/{subscriptionsId}:reactivate","path_regex":"^(?:/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::reactivate)$","service_name":"google.workspaceevents","resource_name":"workspaceevents.subscriptions.reactivate"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.delete"},{"hostname":"workstations.googleapis.com","http_method":"DELETE","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.delete"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.getIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations:listUsable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations:listUsable)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.listUsable"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:getIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.getIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs:listUsable","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs:listUsable)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.listUsable"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.list"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.get"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.getIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations:listUsable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations:listUsable)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.listUsable"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:getIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::getIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.getIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"GET","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs:listUsable","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs:listUsable)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.listUsable"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.patch"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.patch"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.patch"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.patch"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.patch"},{"hostname":"workstations.googleapis.com","http_method":"PATCH","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.patch"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.cancel"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:generateAccessToken","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAccessToken)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.generateAccessToken"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.setIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:start","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.start"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:stop","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.stop"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.testIamPermissions"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:setIamPolicy","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.setIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:testIamPermissions","path_regex":"^(?:/v1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.testIamPermissions"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/operations/{operationsId}:cancel","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::cancel)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.operations.cancel"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.create"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:generateAccessToken","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::generateAccessToken)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.generateAccessToken"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.setIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:start","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::start)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.start"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:stop","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::stop)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.stop"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}/workstations/{workstationsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.workstations.testIamPermissions"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:setIamPolicy","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::setIamPolicy)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.setIamPolicy"},{"hostname":"workstations.googleapis.com","http_method":"POST","path_template":"/v1beta/projects/{projectsId}/locations/{locationsId}/workstationClusters/{workstationClustersId}/workstationConfigs/{workstationConfigsId}:testIamPermissions","path_regex":"^(?:/v1beta/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationClusters/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/workstationConfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?::testIamPermissions)$","service_name":"google.workstations","resource_name":"workstations.projects.locations.workstationClusters.workstationConfigs.testIamPermissions"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsense/v1.4/accounts/{accountId}/alerts/{alertId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsense/v1.4/alerts/{alertId}","path_regex":"^(?:/adsense/v1\\.4/alerts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.alerts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/adsensehost/v4.1/adclients/{adClientId}/urlchannels/{urlChannelId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.urlchannels.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/appstate/v1/states/{stateKey}","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appstate","resource_name":"appstate.states.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dynamicTargetingKeys/{objectId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/drives/{driveId}","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/trash","path_regex":"^(?:/drive/v2/files/trash)$","service_name":"google.drive","resource_name":"drive.files.emptyTrash"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/parents/{parentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.parents.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/files/{folderId}/children/{childId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.children.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v2/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v2/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/drives/{driveId}","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/trash","path_regex":"^(?:/drive/v3/files/trash)$","service_name":"google.drive","resource_name":"drive.files.emptyTrash"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/drive/v3/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v3/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/subscriptions/{id}","path_regex":"^(?:/mirror/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.subscriptions.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/mirror/v1/timeline/{itemId}/attachments/{attachmentId}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/surveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.surveys","resource_name":"surveys.surveys.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sites.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/youtube/analytics/v1beta1/groupItems","path_regex":"^(?:/youtube/analytics/v1beta1/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.delete"},{"hostname":"www.googleapis.com","http_method":"DELETE","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.delete"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/accounts","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.2/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.2/creatives/{accountId}/{buyerCreativeId}","path_regex":"^(?:/adexchangebuyer/v1\\.2/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/accounts","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/billinginfo","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.3/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/creatives/{accountId}/{buyerCreativeId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/directdeals","path_regex":"^(?:/adexchangebuyer/v1\\.3/directdeals)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.directDeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/directdeals/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/directdeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.directDeals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/performancereport","path_regex":"^(?:/adexchangebuyer/v1\\.3/performancereport)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.performanceReport.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/accounts","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/billinginfo","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.billingInfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}/listDeals","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listDeals)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.listDeals"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/performancereport","path_regex":"^(?:/adexchangebuyer/v1\\.4/performancereport)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.performanceReport.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/products/search","path_regex":"^(?:/adexchangebuyer/v1\\.4/products/search)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.products.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/products/{productId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.products.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/search","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/search)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/notes","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacenotes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangebuyer/v1.4/publisher/{accountId}/profiles","path_regex":"^(?:/adexchangebuyer/v1\\.4/publisher/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pubprofiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/accounts/{accountId}","path_regex":"^(?:/adexchangeseller/v1\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/adunits","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adexchangeseller/v1\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/alerts","path_regex":"^(?:/adexchangeseller/v1\\.1/alerts)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/metadata/dimensions","path_regex":"^(?:/adexchangeseller/v1\\.1/metadata/dimensions)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/metadata/metrics","path_regex":"^(?:/adexchangeseller/v1\\.1/metadata/metrics)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/preferreddeals","path_regex":"^(?:/adexchangeseller/v1\\.1/preferreddeals)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.preferreddeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/preferreddeals/{dealId}","path_regex":"^(?:/adexchangeseller/v1\\.1/preferreddeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.preferreddeals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/reports","path_regex":"^(?:/adexchangeseller/v1\\.1/reports)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/reports/saved","path_regex":"^(?:/adexchangeseller/v1\\.1/reports/saved)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1.1/reports/{savedReportId}","path_regex":"^(?:/adexchangeseller/v1\\.1/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients","path_regex":"^(?:/adexchangeseller/v1/adclients)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/adunits","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adexchangeseller/v1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/reports","path_regex":"^(?:/adexchangeseller/v1/reports)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/reports/saved","path_regex":"^(?:/adexchangeseller/v1/reports/saved)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v1/reports/{savedReportId}","path_regex":"^(?:/adexchangeseller/v1/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients/{adClientId}/customchannels","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/alerts","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/metadata/dimensions","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata/dimensions)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/metadata/metrics","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metadata/metrics)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/preferreddeals","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferreddeals)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.preferreddeals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/preferreddeals/{dealId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/preferreddeals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.preferreddeals.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/reports","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/reports/saved","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adexchangeseller/v2.0/accounts/{accountId}/reports/{savedReportId}","path_regex":"^(?:/adexchangeseller/v2\\.0/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangeseller","resource_name":"adexchangeseller.accounts.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts","path_regex":"^(?:/adsense/v1\\.3/accounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/alerts","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/reports","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/reports/saved","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/savedadstyles","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/accounts/{accountId}/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients","path_regex":"^(?:/adsense/v1\\.3/adclients)$","service_name":"google.adsense","resource_name":"adsense.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.3/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/alerts","path_regex":"^(?:/adsense/v1\\.3/alerts)$","service_name":"google.adsense","resource_name":"adsense.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/metadata/dimensions","path_regex":"^(?:/adsense/v1\\.3/metadata/dimensions)$","service_name":"google.adsense","resource_name":"adsense.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/metadata/metrics","path_regex":"^(?:/adsense/v1\\.3/metadata/metrics)$","service_name":"google.adsense","resource_name":"adsense.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/reports","path_regex":"^(?:/adsense/v1\\.3/reports)$","service_name":"google.adsense","resource_name":"adsense.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/reports/saved","path_regex":"^(?:/adsense/v1\\.3/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.3/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/savedadstyles","path_regex":"^(?:/adsense/v1\\.3/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.3/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.3/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts","path_regex":"^(?:/adsense/v1\\.4/accounts)$","service_name":"google.adsense","resource_name":"adsense.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adcode","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adclients.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.accounts.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.accounts.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/alerts","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/alerts)$","service_name":"google.adsense","resource_name":"adsense.accounts.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/payments","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/payments)$","service_name":"google.adsense","resource_name":"adsense.accounts.payments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/reports","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/reports/saved","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/savedadstyles","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/accounts/{accountId}/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.accounts.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients","path_regex":"^(?:/adsense/v1\\.4/adclients)$","service_name":"google.adsense","resource_name":"adsense.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsense","resource_name":"adsense.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/adunits/{adUnitId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.adunits.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsense","resource_name":"adsense.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/customchannels/{customChannelId}/adunits","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsense","resource_name":"adsense.customchannels.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsense/v1\\.4/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsense","resource_name":"adsense.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/alerts","path_regex":"^(?:/adsense/v1\\.4/alerts)$","service_name":"google.adsense","resource_name":"adsense.alerts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/metadata/dimensions","path_regex":"^(?:/adsense/v1\\.4/metadata/dimensions)$","service_name":"google.adsense","resource_name":"adsense.metadata.dimensions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/metadata/metrics","path_regex":"^(?:/adsense/v1\\.4/metadata/metrics)$","service_name":"google.adsense","resource_name":"adsense.metadata.metrics.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/payments","path_regex":"^(?:/adsense/v1\\.4/payments)$","service_name":"google.adsense","resource_name":"adsense.payments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/reports","path_regex":"^(?:/adsense/v1\\.4/reports)$","service_name":"google.adsense","resource_name":"adsense.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/reports/saved","path_regex":"^(?:/adsense/v1\\.4/reports/saved)$","service_name":"google.adsense","resource_name":"adsense.reports.saved.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/reports/{savedReportId}","path_regex":"^(?:/adsense/v1\\.4/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.reports.saved.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/savedadstyles","path_regex":"^(?:/adsense/v1\\.4/savedadstyles)$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsense/v1.4/savedadstyles/{savedAdStyleId}","path_regex":"^(?:/adsense/v1\\.4/savedadstyles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsense","resource_name":"adsense.savedadstyles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts","path_regex":"^(?:/adsensehost/v4\\.1/accounts)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adclients.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits/{adUnitId}/adcode","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adcode)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.getAdCode"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/accounts/{accountId}/reports","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients","path_regex":"^(?:/adsensehost/v4\\.1/adclients)$","service_name":"google.adsensehost","resource_name":"adsensehost.adclients.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.adclients.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels/{customChannelId}","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.urlchannels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/associationsessions/start","path_regex":"^(?:/adsensehost/v4\\.1/associationsessions/start)$","service_name":"google.adsensehost","resource_name":"adsensehost.associationsessions.start"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/associationsessions/verify","path_regex":"^(?:/adsensehost/v4\\.1/associationsessions/verify)$","service_name":"google.adsensehost","resource_name":"adsensehost.associationsessions.verify"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/adsensehost/v4.1/reports","path_regex":"^(?:/adsensehost/v4\\.1/reports)$","service_name":"google.adsensehost","resource_name":"adsensehost.reports.generate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/data","path_regex":"^(?:/analytics/v2\\.4/data)$","service_name":"google.analytics","resource_name":"analytics.data.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts","path_regex":"^(?:/analytics/v2\\.4/management/accounts)$","service_name":"google.analytics","resource_name":"analytics.management.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts/{accountId}/webproperties","path_regex":"^(?:/analytics/v2\\.4/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties)$","service_name":"google.analytics","resource_name":"analytics.management.webproperties.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles","path_regex":"^(?:/analytics/v2\\.4/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles)$","service_name":"google.analytics","resource_name":"analytics.management.profiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/accounts/{accountId}/webproperties/{webPropertyId}/profiles/{profileId}/goals","path_regex":"^(?:/analytics/v2\\.4/management/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/webproperties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/profiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/goals)$","service_name":"google.analytics","resource_name":"analytics.management.goals.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/analytics/v2.4/management/segments","path_regex":"^(?:/analytics/v2\\.4/management/segments)$","service_name":"google.analytics","resource_name":"analytics.management.segments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v1.1/applications/{packageName}/inapp/{productId}/purchases/{token}","path_regex":"^(?:/androidpublisher/v1\\.1/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inapp/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.inapppurchases.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v2/applications/{packageName}/purchases/products/{productId}/tokens/{token}","path_regex":"^(?:/androidpublisher/v2/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/products/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tokens/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.products.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/androidpublisher/v2/applications/{packageName}/purchases/voidedpurchases","path_regex":"^(?:/androidpublisher/v2/applications/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/purchases/voidedpurchases)$","service_name":"google.androidpublisher","resource_name":"androidpublisher.purchases.voidedpurchases.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/appsactivity/v1/activities","path_regex":"^(?:/appsactivity/v1/activities)$","service_name":"google.appsactivity","resource_name":"appsactivity.activities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/appstate/v1/states","path_regex":"^(?:/appstate/v1/states)$","service_name":"google.appstate","resource_name":"appstate.states.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/appstate/v1/states/{stateKey}","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appstate","resource_name":"appstate.states.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/byurl","path_regex":"^(?:/blogger/v3/blogs/byurl)$","service_name":"google.blogger","resource_name":"blogger.blogs.getByUrl"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/comments","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.listByBlog"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/pages","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/pageviews","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pageviews)$","service_name":"google.blogger","resource_name":"blogger.pageViews.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/bypath","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/bypath)$","service_name":"google.blogger","resource_name":"blogger.posts.getByPath"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/search","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/search)$","service_name":"google.blogger","resource_name":"blogger.posts.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.blogger","resource_name":"blogger.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.users.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs)$","service_name":"google.blogger","resource_name":"blogger.blogs.listByUser"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs/{blogId}","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.blogUserInfos.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs/{blogId}/posts","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/blogger/v3/users/{userId}/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/users/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.postUserInfos.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/acl","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.calendar","resource_name":"calendar.acl.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/events","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.calendar","resource_name":"calendar.events.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}/instances","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instances)$","service_name":"google.calendar","resource_name":"calendar.events.instances"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/colors","path_regex":"^(?:/calendar/v3/colors)$","service_name":"google.calendar","resource_name":"calendar.colors.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/calendarList","path_regex":"^(?:/calendar/v3/users/me/calendarList)$","service_name":"google.calendar","resource_name":"calendar.calendarList.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/settings","path_regex":"^(?:/calendar/v3/users/me/settings)$","service_name":"google.calendar","resource_name":"calendar.settings.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/calendar/v3/users/me/settings/{setting}","path_regex":"^(?:/calendar/v3/users/me/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.settings.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/mobileAppPanels","path_regex":"^(?:/consumersurveys/v2/mobileAppPanels)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.mobileapppanels.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/mobileAppPanels/{panelId}","path_regex":"^(?:/consumersurveys/v2/mobileAppPanels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.mobileapppanels.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/surveys","path_regex":"^(?:/consumersurveys/v2/surveys)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}/results","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.results.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orderreturns","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns)$","service_name":"google.content","resource_name":"content.orderreturns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orderreturns/{returnId}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderreturns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orderreturns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orders","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.content","resource_name":"content.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/ordersbymerchantid/{merchantOrderId}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ordersbymerchantid/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.getbymerchantorderid"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/content/v2sandbox/{merchantId}/testordertemplates/{templateName}","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testordertemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.content","resource_name":"content.orders.gettestordertemplate"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v2\\.7/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySiteContacts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySiteContacts/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.0/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySiteContacts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySiteContacts/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.1/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.2/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountActiveAdSummaries/{summaryAccountId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountActiveAdSummaries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountActiveAdSummaries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissionGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountPermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountPermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountPermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/browsers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/browsers)$","service_name":"google.dfareporting","resource_name":"dfareporting.browsers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/changeLogs","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs)$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/changeLogs/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/changeLogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.changeLogs.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/cities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cities)$","service_name":"google.dfareporting","resource_name":"dfareporting.cities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/connectionTypes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/connectionTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/connectionTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.connectionTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/countries","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries)$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/countries/{dartId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/countries/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.countries.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySiteContacts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySiteContacts/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySiteContacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySiteContacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySites/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/files","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/languages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/languages)$","service_name":"google.dfareporting","resource_name":"dfareporting.languages.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/metros","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/metros)$","service_name":"google.dfareporting","resource_name":"dfareporting.metros.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileApps","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileApps/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileApps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileApps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileCarriers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers)$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/mobileCarriers/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/mobileCarriers/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.mobileCarriers.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystemVersions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystemVersions/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystemVersions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystemVersions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystems","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems)$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/operatingSystems/{dartId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operatingSystems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.operatingSystems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/platformTypes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes)$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/platformTypes/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/platformTypes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.platformTypes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/postalCodes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes)$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/postalCodes/{code}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/postalCodes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.postalCodes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects)$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.projects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/inventoryItems","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems)$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/inventoryItems/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inventoryItems/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.inventoryItems.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orderDocuments","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments)$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orderDocuments/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderDocuments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orderDocuments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orders","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders)$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/projects/{projectId}/orders/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.orders.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/regions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/regions)$","service_name":"google.dfareporting","resource_name":"dfareporting.regions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingListShares/{remarketingListId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}/files","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}/files/{fileId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sizes/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetableRemarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetableRemarketingLists/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetableRemarketingLists/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetableRemarketingLists.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissionGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissionGroups/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissionGroups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissionGroups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissions","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRolePermissions/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRolePermissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRolePermissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/videoFormats","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats)$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/videoFormats/{id}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/videoFormats/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.videoFormats.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/discovery/v1/apis","path_regex":"^(?:/discovery/v1/apis)$","service_name":"google.discovery","resource_name":"discovery.apis.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/discovery/v1/apis/{api}/{version}/rest","path_regex":"^(?:/discovery/v1/apis/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rest)$","service_name":"google.discovery","resource_name":"discovery.apis.getRest"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/about","path_regex":"^(?:/drive/v2/about)$","service_name":"google.drive","resource_name":"drive.about.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/apps","path_regex":"^(?:/drive/v2/apps)$","service_name":"google.drive","resource_name":"drive.apps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/apps/{appId}","path_regex":"^(?:/drive/v2/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.apps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/changes","path_regex":"^(?:/drive/v2/changes)$","service_name":"google.drive","resource_name":"drive.changes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/changes/startPageToken","path_regex":"^(?:/drive/v2/changes/startPageToken)$","service_name":"google.drive","resource_name":"drive.changes.getStartPageToken"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/changes/{changeId}","path_regex":"^(?:/drive/v2/changes/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.changes.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/drives","path_regex":"^(?:/drive/v2/drives)$","service_name":"google.drive","resource_name":"drive.drives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/drives/{driveId}","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files","path_regex":"^(?:/drive/v2/files)$","service_name":"google.drive","resource_name":"drive.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/generateIds","path_regex":"^(?:/drive/v2/files/generateIds)$","service_name":"google.drive","resource_name":"drive.files.generateIds"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/export","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.drive","resource_name":"drive.files.export"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/listLabels","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listLabels)$","service_name":"google.drive","resource_name":"drive.files.listLabels"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/parents","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents)$","service_name":"google.drive","resource_name":"drive.parents.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/parents/{parentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.parents.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/permissions","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/properties","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties)$","service_name":"google.drive","resource_name":"drive.properties.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/revisions","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.drive","resource_name":"drive.revisions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{folderId}/children","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children)$","service_name":"google.drive","resource_name":"drive.children.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/files/{folderId}/children/{childId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.children.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/permissionIds/{email}","path_regex":"^(?:/drive/v2/permissionIds/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.getIdForEmail"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/teamdrives","path_regex":"^(?:/drive/v2/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v2/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v2/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/about","path_regex":"^(?:/drive/v3/about)$","service_name":"google.drive","resource_name":"drive.about.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/apps","path_regex":"^(?:/drive/v3/apps)$","service_name":"google.drive","resource_name":"drive.apps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/apps/{appId}","path_regex":"^(?:/drive/v3/apps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.apps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/changes","path_regex":"^(?:/drive/v3/changes)$","service_name":"google.drive","resource_name":"drive.changes.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/changes/startPageToken","path_regex":"^(?:/drive/v3/changes/startPageToken)$","service_name":"google.drive","resource_name":"drive.changes.getStartPageToken"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/drives","path_regex":"^(?:/drive/v3/drives)$","service_name":"google.drive","resource_name":"drive.drives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/drives/{driveId}","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files","path_regex":"^(?:/drive/v3/files)$","service_name":"google.drive","resource_name":"drive.files.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/generateIds","path_regex":"^(?:/drive/v3/files/generateIds)$","service_name":"google.drive","resource_name":"drive.files.generateIds"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/export","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/export)$","service_name":"google.drive","resource_name":"drive.files.export"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/listLabels","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/listLabels)$","service_name":"google.drive","resource_name":"drive.files.listLabels"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/permissions","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/revisions","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions)$","service_name":"google.drive","resource_name":"drive.revisions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/teamdrives","path_regex":"^(?:/drive/v3/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/drive/v3/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v3/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/query","path_regex":"^(?:/fusiontables/v1/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sqlGet"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables","path_regex":"^(?:/fusiontables/v1/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/tasks","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.fusiontables","resource_name":"fusiontables.task.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/query","path_regex":"^(?:/fusiontables/v2/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sqlGet"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables","path_regex":"^(?:/fusiontables/v2/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/tasks","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks)$","service_name":"google.fusiontables","resource_name":"fusiontables.task.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/tasks/{taskId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/tasks/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.task.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/groups/v1/groups/{groupUniqueId}","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.groupssettings","resource_name":"groupsSettings.groups.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/identitytoolkit/v3/relyingparty/getProjectConfig","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getProjectConfig)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getProjectConfig"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/identitytoolkit/v3/relyingparty/getRecaptchaParam","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getRecaptchaParam)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getRecaptchaParam"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/identitytoolkit/v3/relyingparty/publicKeys","path_regex":"^(?:/identitytoolkit/v3/relyingparty/publicKeys)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getPublicKeys"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/contacts","path_regex":"^(?:/mirror/v1/contacts)$","service_name":"google.mirror","resource_name":"mirror.contacts.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/locations","path_regex":"^(?:/mirror/v1/locations)$","service_name":"google.mirror","resource_name":"mirror.locations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/locations/{id}","path_regex":"^(?:/mirror/v1/locations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.locations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/settings/{id}","path_regex":"^(?:/mirror/v1/settings/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.settings.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/subscriptions","path_regex":"^(?:/mirror/v1/subscriptions)$","service_name":"google.mirror","resource_name":"mirror.subscriptions.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline","path_regex":"^(?:/mirror/v1/timeline)$","service_name":"google.mirror","resource_name":"mirror.timeline.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline/{itemId}/attachments","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/mirror/v1/timeline/{itemId}/attachments/{attachmentId}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/oauth2/v1/userinfo","path_regex":"^(?:/oauth2/v1/userinfo)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/oauth2/v2/userinfo","path_regex":"^(?:/oauth2/v2/userinfo)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v1/runPagespeed","path_regex":"^(?:/pagespeedonline/v1/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v2/runPagespeed","path_regex":"^(?:/pagespeedonline/v2/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/pagespeedonline/v4/runPagespeed","path_regex":"^(?:/pagespeedonline/v4/runPagespeed)$","service_name":"google.pagespeedonline","resource_name":"pagespeedonline.pagespeedapi.runpagespeed"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities","path_regex":"^(?:/plus/v1/activities)$","service_name":"google.plus","resource_name":"plus.activities.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities/{activityId}","path_regex":"^(?:/plus/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.activities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities/{activityId}/comments","path_regex":"^(?:/plus/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.plus","resource_name":"plus.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/activities/{activityId}/people/{collection}","path_regex":"^(?:/plus/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.people.listByActivity"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/comments/{commentId}","path_regex":"^(?:/plus/v1/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people","path_regex":"^(?:/plus/v1/people)$","service_name":"google.plus","resource_name":"plus.people.search"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people/{userId}","path_regex":"^(?:/plus/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.people.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people/{userId}/activities/{collection}","path_regex":"^(?:/plus/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.activities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plus/v1/people/{userId}/people/{collection}","path_regex":"^(?:/plus/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plus","resource_name":"plus.people.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/activities/{activityId}","path_regex":"^(?:/plusDomains/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.activities.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/activities/{activityId}/comments","path_regex":"^(?:/plusDomains/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.plusDomains","resource_name":"plusDomains.comments.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/activities/{activityId}/people/{collection}","path_regex":"^(?:/plusDomains/v1/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.people.listByActivity"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/comments/{commentId}","path_regex":"^(?:/plusDomains/v1/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.comments.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.people.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/activities/{collection}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/activities/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.activities.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/audiences","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/audiences)$","service_name":"google.plusDomains","resource_name":"plusDomains.audiences.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/circles","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/circles)$","service_name":"google.plusDomains","resource_name":"plusDomains.circles.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/plusDomains/v1/people/{userId}/people/{collection}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.people.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools)$","service_name":"google.replicapool","resource_name":"replicapool.pools.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.pools.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas)$","service_name":"google.replicapool","resource_name":"replicapool.replicas.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas/{replicaName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.replicas.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/operations","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.zoneOperations.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/operations/{operation}","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/operations/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.zoneOperations.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/instanceUpdates","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/instanceUpdates)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.listInstanceUpdates"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/siteVerification/v1/webResource","path_regex":"^(?:/siteVerification/v1/webResource)$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1/b/{bucket}","path_regex":"^(?:/storage/v1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b","path_regex":"^(?:/storage/v1beta1/b)$","service_name":"google.storage","resource_name":"storage.buckets.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/surveys/v2/surveys","path_regex":"^(?:/surveys/v2/surveys)$","service_name":"google.surveys","resource_name":"surveys.surveys.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/surveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.surveys","resource_name":"surveys.surveys.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/surveys/v2/surveys/{surveyUrlId}/results","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/results)$","service_name":"google.surveys","resource_name":"surveys.results.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/urlshortener/v1/url","path_regex":"^(?:/urlshortener/v1/url)$","service_name":"google.urlshortener","resource_name":"urlshortener.url.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/urlshortener/v1/url/history","path_regex":"^(?:/urlshortener/v1/url/history)$","service_name":"google.urlshortener","resource_name":"urlshortener.url.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/userinfo/v2/me","path_regex":"^(?:/userinfo/v2/me)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.v2.me.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/userinfo/v2/me","path_regex":"^(?:/userinfo/v2/me)$","service_name":"google.oauth2","resource_name":"oauth2.userinfo.v2.me.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites","path_regex":"^(?:/webmasters/v3/sites)$","service_name":"google.webmasters","resource_name":"webmasters.sites.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sites.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps)$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.get"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/youtube/analytics/v1beta1/groupItems","path_regex":"^(?:/youtube/analytics/v1beta1/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.list"},{"hostname":"www.googleapis.com","http_method":"GET","path_template":"/youtube/analytics/v1beta1/reports","path_regex":"^(?:/youtube/analytics/v1beta1/reports)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.reports.query"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.2/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.3/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/{revisionNumber}/{updateAction}","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/drives/{driveId}","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/drive/v3/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v3/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.update"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/groups/v1/groups/{groupUniqueId}","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.groupssettings","resource_name":"groupsSettings.groups.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.patch"},{"hostname":"www.googleapis.com","http_method":"PATCH","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.patch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.2/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.2/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.3/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.3/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/creatives","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}/addDeal/{dealId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/addDeal/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.addDeal"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/creatives/{accountId}/{buyerCreativeId}/removeDeal/{dealId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/creatives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removeDeal/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.creatives.removeDeal"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/privateauction/{privateAuctionId}/updateproposal","path_regex":"^(?:/adexchangebuyer/v1\\.4/privateauction/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateproposal)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplaceprivateauction.updateproposal"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/insert","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/insert)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals/delete","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/delete)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.delete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals/insert","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/insert)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/deals/update","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/deals/update)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacedeals.update"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/notes/insert","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notes/insert)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.marketplacenotes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/setupcomplete","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setupcomplete)$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.setupcomplete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/adsensehost/v4.1/adclients/{adClientId}/urlchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/urlchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.urlchannels.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/appstate/v1/states/{stateKey}/clear","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clear)$","service_name":"google.appstate","resource_name":"appstate.states.clear"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/pages","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages)$","service_name":"google.blogger","resource_name":"blogger.pages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts)$","service_name":"google.blogger","resource_name":"blogger.posts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/approve","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/approve)$","service_name":"google.blogger","resource_name":"blogger.comments.approve"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/removecontent","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/removecontent)$","service_name":"google.blogger","resource_name":"blogger.comments.removeContent"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/comments/{commentId}/spam","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/spam)$","service_name":"google.blogger","resource_name":"blogger.comments.markAsSpam"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/publish","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/publish)$","service_name":"google.blogger","resource_name":"blogger.posts.publish"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}/revert","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revert)$","service_name":"google.blogger","resource_name":"blogger.posts.revert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars","path_regex":"^(?:/calendar/v3/calendars)$","service_name":"google.calendar","resource_name":"calendar.calendars.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/acl","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.calendar","resource_name":"calendar.acl.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/acl/watch","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/watch)$","service_name":"google.calendar","resource_name":"calendar.acl.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/clear","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/clear)$","service_name":"google.calendar","resource_name":"calendar.calendars.clear"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events)$","service_name":"google.calendar","resource_name":"calendar.events.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/import","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/import)$","service_name":"google.calendar","resource_name":"calendar.events.import"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/quickAdd","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/quickAdd)$","service_name":"google.calendar","resource_name":"calendar.events.quickAdd"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/watch","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/watch)$","service_name":"google.calendar","resource_name":"calendar.events.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}/move","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/move)$","service_name":"google.calendar","resource_name":"calendar.events.move"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/channels/stop","path_regex":"^(?:/calendar/v3/channels/stop)$","service_name":"google.calendar","resource_name":"calendar.channels.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/freeBusy","path_regex":"^(?:/calendar/v3/freeBusy)$","service_name":"google.calendar","resource_name":"calendar.freebusy.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/users/me/calendarList","path_regex":"^(?:/calendar/v3/users/me/calendarList)$","service_name":"google.calendar","resource_name":"calendar.calendarList.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/users/me/calendarList/watch","path_regex":"^(?:/calendar/v3/users/me/calendarList/watch)$","service_name":"google.calendar","resource_name":"calendar.calendarList.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/calendar/v3/users/me/settings/watch","path_regex":"^(?:/calendar/v3/users/me/settings/watch)$","service_name":"google.calendar","resource_name":"calendar.settings.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/consumersurveys/v2/surveys","path_regex":"^(?:/consumersurveys/v2/surveys)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/consumersurveys/v2/surveys/{resourceId}/start","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.start"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/consumersurveys/v2/surveys/{resourceId}/stop","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/orders/batch","path_regex":"^(?:/content/v2sandbox/orders/batch)$","service_name":"google.content","resource_name":"content.orders.custombatch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderinvoices/{orderId}/createChargeInvoice","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createChargeInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createchargeinvoice"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderinvoices/{orderId}/createRefundInvoice","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderinvoices/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/createRefundInvoice)$","service_name":"google.content","resource_name":"content.orderinvoices.createrefundinvoice"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyAuthApproved","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyAuthApproved)$","service_name":"google.content","resource_name":"content.orderpayments.notifyauthapproved"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyAuthDeclined","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyAuthDeclined)$","service_name":"google.content","resource_name":"content.orderpayments.notifyauthdeclined"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyCharge","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyCharge)$","service_name":"google.content","resource_name":"content.orderpayments.notifycharge"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orderpayments/{orderId}/notifyRefund","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orderpayments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/notifyRefund)$","service_name":"google.content","resource_name":"content.orderpayments.notifyrefund"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/acknowledge","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acknowledge)$","service_name":"google.content","resource_name":"content.orders.acknowledge"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/cancel","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.content","resource_name":"content.orders.cancel"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/cancelLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelLineItem)$","service_name":"google.content","resource_name":"content.orders.cancellineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/inStoreRefundLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/inStoreRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.instorerefundlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/refund","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refund)$","service_name":"google.content","resource_name":"content.orders.refund"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/rejectReturnLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rejectReturnLineItem)$","service_name":"google.content","resource_name":"content.orders.rejectreturnlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/returnLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnLineItem)$","service_name":"google.content","resource_name":"content.orders.returnlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/returnRefundLineItem","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/returnRefundLineItem)$","service_name":"google.content","resource_name":"content.orders.returnrefundlineitem"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/setLineItemMetadata","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/setLineItemMetadata)$","service_name":"google.content","resource_name":"content.orders.setlineitemmetadata"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/shipLineItems","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/shipLineItems)$","service_name":"google.content","resource_name":"content.orders.shiplineitems"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/testreturn","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testreturn)$","service_name":"google.content","resource_name":"content.orders.createtestreturn"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/updateLineItemShippingDetails","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateLineItemShippingDetails)$","service_name":"google.content","resource_name":"content.orders.updatelineitemshippingdetails"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/updateMerchantOrderId","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateMerchantOrderId)$","service_name":"google.content","resource_name":"content.orders.updatemerchantorderid"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/orders/{orderId}/updateShipment","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/orders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateShipment)$","service_name":"google.content","resource_name":"content.orders.updateshipment"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/testorders","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders)$","service_name":"google.content","resource_name":"content.orders.createtestorder"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/testorders/{orderId}/advance","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advance)$","service_name":"google.content","resource_name":"content.orders.advancetestorder"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/content/v2sandbox/{merchantId}/testorders/{orderId}/cancelByCustomer","path_regex":"^(?:/content/v2sandbox/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/testorders/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancelByCustomer)$","service_name":"google.content","resource_name":"content.orders.canceltestorderbycustomer"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns/{campaignId}/campaignCreativeAssociations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaignCreativeAssociations)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaignCreativeAssociations.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/conversions/batchinsert","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchinsert)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchinsert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/conversions/batchupdate","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/conversions/batchupdate)$","service_name":"google.dfareporting","resource_name":"dfareporting.conversions.batchupdate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeAssets/{advertiserId}/creativeAssets","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeAssets)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeAssets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dimensionvalues/query","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dimensionvalues/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.dimensionValues.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/directorySites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/directorySites)$","service_name":"google.dfareporting","resource_name":"dfareporting.directorySites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/dynamicTargetingKeys","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/dynamicTargetingKeys)$","service_name":"google.dfareporting","resource_name":"dfareporting.dynamicTargetingKeys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities/generatetag","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities/generatetag)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.generatetag"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements/generatetags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements/generatetags)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.generatetags"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/compatiblefields/query","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/compatiblefields/query)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.compatibleFields.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}/run","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/run)$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.run"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sizes","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sizes)$","service_name":"google.dfareporting","resource_name":"dfareporting.sizes.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/changes/watch","path_regex":"^(?:/drive/v2/changes/watch)$","service_name":"google.drive","resource_name":"drive.changes.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/channels/stop","path_regex":"^(?:/drive/v2/channels/stop)$","service_name":"google.drive","resource_name":"drive.channels.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/drives","path_regex":"^(?:/drive/v2/drives)$","service_name":"google.drive","resource_name":"drive.drives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/drives/{driveId}/hide","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hide)$","service_name":"google.drive","resource_name":"drive.drives.hide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/drives/{driveId}/unhide","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unhide)$","service_name":"google.drive","resource_name":"drive.drives.unhide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files","path_regex":"^(?:/drive/v2/files)$","service_name":"google.drive","resource_name":"drive.files.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/comments","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/copy","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.drive","resource_name":"drive.files.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/modifyLabels","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modifyLabels)$","service_name":"google.drive","resource_name":"drive.files.modifyLabels"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/parents","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/parents)$","service_name":"google.drive","resource_name":"drive.parents.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/permissions","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/properties","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties)$","service_name":"google.drive","resource_name":"drive.properties.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/touch","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/touch)$","service_name":"google.drive","resource_name":"drive.files.touch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/trash","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/trash)$","service_name":"google.drive","resource_name":"drive.files.trash"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/untrash","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/untrash)$","service_name":"google.drive","resource_name":"drive.files.untrash"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{fileId}/watch","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.drive","resource_name":"drive.files.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/files/{folderId}/children","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/children)$","service_name":"google.drive","resource_name":"drive.children.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v2/teamdrives","path_regex":"^(?:/drive/v2/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/changes/watch","path_regex":"^(?:/drive/v3/changes/watch)$","service_name":"google.drive","resource_name":"drive.changes.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/channels/stop","path_regex":"^(?:/drive/v3/channels/stop)$","service_name":"google.drive","resource_name":"drive.channels.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/drives","path_regex":"^(?:/drive/v3/drives)$","service_name":"google.drive","resource_name":"drive.drives.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/drives/{driveId}/hide","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/hide)$","service_name":"google.drive","resource_name":"drive.drives.hide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/drives/{driveId}/unhide","path_regex":"^(?:/drive/v3/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/unhide)$","service_name":"google.drive","resource_name":"drive.drives.unhide"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files","path_regex":"^(?:/drive/v3/files)$","service_name":"google.drive","resource_name":"drive.files.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/comments","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments)$","service_name":"google.drive","resource_name":"drive.comments.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/comments/{commentId}/replies","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies)$","service_name":"google.drive","resource_name":"drive.replies.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/copy","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.drive","resource_name":"drive.files.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/modifyLabels","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/modifyLabels)$","service_name":"google.drive","resource_name":"drive.files.modifyLabels"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/permissions","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions)$","service_name":"google.drive","resource_name":"drive.permissions.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/files/{fileId}/watch","path_regex":"^(?:/drive/v3/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/watch)$","service_name":"google.drive","resource_name":"drive.files.watch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/drive/v3/teamdrives","path_regex":"^(?:/drive/v3/teamdrives)$","service_name":"google.drive","resource_name":"drive.teamdrives.create"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/query","path_regex":"^(?:/fusiontables/v1/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sql"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables","path_regex":"^(?:/fusiontables/v1/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/import","path_regex":"^(?:/fusiontables/v1/tables/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importTable"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/copy","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/import","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importRows"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v1/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/query","path_regex":"^(?:/fusiontables/v2/query)$","service_name":"google.fusiontables","resource_name":"fusiontables.query.sql"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables","path_regex":"^(?:/fusiontables/v2/tables)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/import","path_regex":"^(?:/fusiontables/v2/tables/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importTable"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/columns","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns)$","service_name":"google.fusiontables","resource_name":"fusiontables.column.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/copy","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/copy)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.copy"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/import","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/import)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.importRows"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/refetch","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/refetch)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.refetchSheet"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/replace","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replace)$","service_name":"google.fusiontables","resource_name":"fusiontables.table.replaceRows"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/styles","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles)$","service_name":"google.fusiontables","resource_name":"fusiontables.style.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/fusiontables/v2/tables/{tableId}/templates","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates)$","service_name":"google.fusiontables","resource_name":"fusiontables.template.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/createAuthUri","path_regex":"^(?:/identitytoolkit/v3/relyingparty/createAuthUri)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.createAuthUri"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/deleteAccount","path_regex":"^(?:/identitytoolkit/v3/relyingparty/deleteAccount)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.deleteAccount"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/downloadAccount","path_regex":"^(?:/identitytoolkit/v3/relyingparty/downloadAccount)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.downloadAccount"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/emailLinkSignin","path_regex":"^(?:/identitytoolkit/v3/relyingparty/emailLinkSignin)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.emailLinkSignin"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/getAccountInfo","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getAccountInfo)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getAccountInfo"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/getOobConfirmationCode","path_regex":"^(?:/identitytoolkit/v3/relyingparty/getOobConfirmationCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.getOobConfirmationCode"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/resetPassword","path_regex":"^(?:/identitytoolkit/v3/relyingparty/resetPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.resetPassword"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/sendVerificationCode","path_regex":"^(?:/identitytoolkit/v3/relyingparty/sendVerificationCode)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.sendVerificationCode"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/setAccountInfo","path_regex":"^(?:/identitytoolkit/v3/relyingparty/setAccountInfo)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.setAccountInfo"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/setProjectConfig","path_regex":"^(?:/identitytoolkit/v3/relyingparty/setProjectConfig)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.setProjectConfig"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/signOutUser","path_regex":"^(?:/identitytoolkit/v3/relyingparty/signOutUser)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.signOutUser"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/signupNewUser","path_regex":"^(?:/identitytoolkit/v3/relyingparty/signupNewUser)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.signupNewUser"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/uploadAccount","path_regex":"^(?:/identitytoolkit/v3/relyingparty/uploadAccount)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.uploadAccount"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyAssertion","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyAssertion)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyAssertion"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyCustomToken","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyCustomToken)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyCustomToken"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyPassword","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyPassword)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyPassword"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/identitytoolkit/v3/relyingparty/verifyPhoneNumber","path_regex":"^(?:/identitytoolkit/v3/relyingparty/verifyPhoneNumber)$","service_name":"google.identitytoolkit","resource_name":"identitytoolkit.relyingparty.verifyPhoneNumber"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/accounts/{userToken}/{accountType}/{accountName}","path_regex":"^(?:/mirror/v1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.accounts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/contacts","path_regex":"^(?:/mirror/v1/contacts)$","service_name":"google.mirror","resource_name":"mirror.contacts.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/subscriptions","path_regex":"^(?:/mirror/v1/subscriptions)$","service_name":"google.mirror","resource_name":"mirror.subscriptions.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/timeline","path_regex":"^(?:/mirror/v1/timeline)$","service_name":"google.mirror","resource_name":"mirror.timeline.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/mirror/v1/timeline/{itemId}/attachments","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/attachments)$","service_name":"google.mirror","resource_name":"mirror.timeline.attachments.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/plusDomains/v1/people/{userId}/media/{collection}","path_regex":"^(?:/plusDomains/v1/people/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.plusDomains","resource_name":"plusDomains.media.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/qpxExpress/v1/trips/search","path_regex":"^(?:/qpxExpress/v1/trips/search)$","service_name":"google.qpxExpress","resource_name":"qpxExpress.trips.search"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools)$","service_name":"google.replicapool","resource_name":"replicapool.pools.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.pools.delete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas/{replicaName}","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.replicapool","resource_name":"replicapool.replicas.delete"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/replicas/{replicaName}/restart","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replicas/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/restart)$","service_name":"google.replicapool","resource_name":"replicapool.replicas.restart"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/resize","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resize)$","service_name":"google.replicapool","resource_name":"replicapool.pools.resize"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapool/v1beta1/projects/{projectName}/zones/{zone}/pools/{poolName}/updateTemplate","path_regex":"^(?:/replicapool/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pools/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/updateTemplate)$","service_name":"google.replicapool","resource_name":"replicapool.pools.updatetemplate"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/cancel","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/cancel)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.cancel"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/pause","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pause)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.pause"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/resume","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/resume)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.resume"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/replicapoolupdater/v1beta1/projects/{project}/zones/{zone}/rollingUpdates/{rollingUpdate}/rollback","path_regex":"^(?:/replicapoolupdater/v1beta1/projects/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/zones/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollingUpdates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/rollback)$","service_name":"google.replicapoolupdater","resource_name":"replicapoolupdater.rollingUpdates.rollback"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/siteVerification/v1/token","path_regex":"^(?:/siteVerification/v1/token)$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.getToken"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/siteVerification/v1/webResource","path_regex":"^(?:/siteVerification/v1/webResource)$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/getSpectrum","path_regex":"^(?:/spectrum/v1explorer/paws/getSpectrum)$","service_name":"google.spectrum","resource_name":"spectrum.paws.getSpectrum"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/getSpectrumBatch","path_regex":"^(?:/spectrum/v1explorer/paws/getSpectrumBatch)$","service_name":"google.spectrum","resource_name":"spectrum.paws.getSpectrumBatch"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/init","path_regex":"^(?:/spectrum/v1explorer/paws/init)$","service_name":"google.spectrum","resource_name":"spectrum.paws.init"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/notifySpectrumUse","path_regex":"^(?:/spectrum/v1explorer/paws/notifySpectrumUse)$","service_name":"google.spectrum","resource_name":"spectrum.paws.notifySpectrumUse"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/register","path_regex":"^(?:/spectrum/v1explorer/paws/register)$","service_name":"google.spectrum","resource_name":"spectrum.paws.register"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/spectrum/v1explorer/paws/verifyDevice","path_regex":"^(?:/spectrum/v1explorer/paws/verifyDevice)$","service_name":"google.spectrum","resource_name":"spectrum.paws.verifyDevice"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b","path_regex":"^(?:/storage/v1beta1/b)$","service_name":"google.storage","resource_name":"storage.buckets.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b/{bucket}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b/{bucket}/o","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o)$","service_name":"google.storage","resource_name":"storage.objects.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl)$","service_name":"google.storage","resource_name":"storage.objectAccessControls.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/surveys/v2/surveys","path_regex":"^(?:/surveys/v2/surveys)$","service_name":"google.surveys","resource_name":"surveys.surveys.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/surveys/v2/surveys/{resourceId}/start","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/start)$","service_name":"google.surveys","resource_name":"surveys.surveys.start"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/surveys/v2/surveys/{resourceId}/stop","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/stop)$","service_name":"google.surveys","resource_name":"surveys.surveys.stop"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/urlshortener/v1/url","path_regex":"^(?:/urlshortener/v1/url)$","service_name":"google.urlshortener","resource_name":"urlshortener.url.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/webmasters/v3/sites/{siteUrl}/searchAnalytics/query","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/searchAnalytics/query)$","service_name":"google.webmasters","resource_name":"webmasters.searchanalytics.query"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/youtube/analytics/v1beta1/groupItems","path_regex":"^(?:/youtube/analytics/v1beta1/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.insert"},{"hostname":"www.googleapis.com","http_method":"POST","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.insert"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.2/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.2/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.3/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.3/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.3/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.3/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.3/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/accounts/{id}","path_regex":"^(?:/adexchangebuyer/v1\\.4/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/billinginfo/{accountId}/{billingId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/billinginfo/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.budget.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/pretargetingconfigs/{accountId}/{configId}","path_regex":"^(?:/adexchangebuyer/v1\\.4/pretargetingconfigs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.pretargetingConfig.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adexchangebuyer/v1.4/proposals/{proposalId}/{revisionNumber}/{updateAction}","path_regex":"^(?:/adexchangebuyer/v1\\.4/proposals/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.adexchangebuyer","resource_name":"adexchangebuyer.proposals.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adsensehost/v4.1/accounts/{accountId}/adclients/{adClientId}/adunits","path_regex":"^(?:/adsensehost/v4\\.1/accounts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/adunits)$","service_name":"google.adsensehost","resource_name":"adsensehost.accounts.adunits.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/adsensehost/v4.1/adclients/{adClientId}/customchannels","path_regex":"^(?:/adsensehost/v4\\.1/adclients/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/customchannels)$","service_name":"google.adsensehost","resource_name":"adsensehost.customchannels.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/appstate/v1/states/{stateKey}","path_regex":"^(?:/appstate/v1/states/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.appstate","resource_name":"appstate.states.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/blogger/v3/blogs/{blogId}/pages/{pageId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/pages/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.pages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/blogger/v3/blogs/{blogId}/posts/{postId}","path_regex":"^(?:/blogger/v3/blogs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/posts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.blogger","resource_name":"blogger.posts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/calendars/{calendarId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendars.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/calendars/{calendarId}/acl/{ruleId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.acl.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/calendars/{calendarId}/events/{eventId}","path_regex":"^(?:/calendar/v3/calendars/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/events/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.events.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/calendar/v3/users/me/calendarList/{calendarId}","path_regex":"^(?:/calendar/v3/users/me/calendarList/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.calendar","resource_name":"calendar.calendarList.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/consumersurveys/v2/mobileAppPanels/{panelId}","path_regex":"^(?:/consumersurveys/v2/mobileAppPanels/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.mobileapppanels.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/consumersurveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/consumersurveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.consumersurveys","resource_name":"consumersurveys.surveys.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/campaigns/{campaignId}/landingPages","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/landingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.landingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v2.7/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v2\\.7/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.0/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.0/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.1/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.1/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accountUserProfiles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accountUserProfiles)$","service_name":"google.dfareporting","resource_name":"dfareporting.accountUserProfiles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/accounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/accounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.accounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/ads","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/ads)$","service_name":"google.dfareporting","resource_name":"dfareporting.ads.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertiserLandingPages","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertiserLandingPages)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertiserLandingPages.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/advertisers","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/advertisers)$","service_name":"google.dfareporting","resource_name":"dfareporting.advertisers.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/campaigns","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/campaigns)$","service_name":"google.dfareporting","resource_name":"dfareporting.campaigns.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/contentCategories","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/contentCategories)$","service_name":"google.dfareporting","resource_name":"dfareporting.contentCategories.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFields.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeFields/{creativeFieldId}/creativeFieldValues","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFields/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeFieldValues)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeFieldValues.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creativeGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creativeGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.creativeGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/creatives","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/creatives)$","service_name":"google.dfareporting","resource_name":"dfareporting.creatives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/eventTags","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/eventTags)$","service_name":"google.dfareporting","resource_name":"dfareporting.eventTags.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivities","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivities)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivities.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightActivityGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightActivityGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightActivityGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/floodlightConfigurations","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/floodlightConfigurations)$","service_name":"google.dfareporting","resource_name":"dfareporting.floodlightConfigurations.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementGroups","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementGroups)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementGroups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placementStrategies","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placementStrategies)$","service_name":"google.dfareporting","resource_name":"dfareporting.placementStrategies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/placements","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/placements)$","service_name":"google.dfareporting","resource_name":"dfareporting.placements.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingListShares","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingListShares)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingListShares.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/remarketingLists","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/remarketingLists)$","service_name":"google.dfareporting","resource_name":"dfareporting.remarketingLists.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/reports/{reportId}","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.dfareporting","resource_name":"dfareporting.reports.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/sites","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sites)$","service_name":"google.dfareporting","resource_name":"dfareporting.sites.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/subaccounts","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/subaccounts)$","service_name":"google.dfareporting","resource_name":"dfareporting.subaccounts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/targetingTemplates","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/targetingTemplates)$","service_name":"google.dfareporting","resource_name":"dfareporting.targetingTemplates.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/dfareporting/v3.2/userprofiles/{profileId}/userRoles","path_regex":"^(?:/dfareporting/v3\\.2/userprofiles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/userRoles)$","service_name":"google.dfareporting","resource_name":"dfareporting.userRoles.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/drives/{driveId}","path_regex":"^(?:/drive/v2/drives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.drives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.files.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/comments/{commentId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.comments.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/comments/{commentId}/replies/{replyId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/comments/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/replies/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.replies.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/permissions/{permissionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/permissions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.permissions.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/properties/{propertyKey}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/properties/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.properties.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/files/{fileId}/revisions/{revisionId}","path_regex":"^(?:/drive/v2/files/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/revisions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.revisions.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/drive/v2/teamdrives/{teamDriveId}","path_regex":"^(?:/drive/v2/teamdrives/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.drive","resource_name":"drive.teamdrives.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v1/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v1/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.table.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}/columns/{columnId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/columns/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.column.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}/styles/{styleId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/styles/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.style.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/fusiontables/v2/tables/{tableId}/templates/{templateId}","path_regex":"^(?:/fusiontables/v2/tables/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/templates/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.fusiontables","resource_name":"fusiontables.template.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/groups/v1/groups/{groupUniqueId}","path_regex":"^(?:/groups/v1/groups/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.groupssettings","resource_name":"groupsSettings.groups.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/mirror/v1/contacts/{id}","path_regex":"^(?:/mirror/v1/contacts/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.contacts.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/mirror/v1/subscriptions/{id}","path_regex":"^(?:/mirror/v1/subscriptions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.subscriptions.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/mirror/v1/timeline/{id}","path_regex":"^(?:/mirror/v1/timeline/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.mirror","resource_name":"mirror.timeline.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/siteVerification/v1/webResource/{id}","path_regex":"^(?:/siteVerification/v1/webResource/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.siteVerification","resource_name":"siteVerification.webResource.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.buckets.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.bucketAccessControls.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}/o/{object}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objects.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/storage/v1beta1/b/{bucket}/o/{object}/acl/{entity}","path_regex":"^(?:/storage/v1beta1/b/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/o/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/acl/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.storage","resource_name":"storage.objectAccessControls.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/surveys/v2/surveys/{surveyUrlId}","path_regex":"^(?:/surveys/v2/surveys/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.surveys","resource_name":"surveys.surveys.update"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sites.add"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/webmasters/v3/sites/{siteUrl}/sitemaps/{feedpath}","path_regex":"^(?:/webmasters/v3/sites/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/sitemaps/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.webmasters","resource_name":"webmasters.sitemaps.submit"},{"hostname":"www.googleapis.com","http_method":"PUT","path_template":"/youtube/analytics/v1beta1/groups","path_regex":"^(?:/youtube/analytics/v1beta1/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.update"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveChat/bans","path_regex":"^(?:/youtube/v3/liveChat/bans)$","service_name":"google.youtube","resource_name":"youtube.liveChatBans.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveChat/messages","path_regex":"^(?:/youtube/v3/liveChat/messages)$","service_name":"google.youtube","resource_name":"youtube.liveChatMessages.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveChat/moderators","path_regex":"^(?:/youtube/v3/liveChat/moderators)$","service_name":"google.youtube","resource_name":"youtube.liveChatModerators.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/playlistImages","path_regex":"^(?:/youtube/v3/playlistImages)$","service_name":"google.youtube","resource_name":"youtube.playlistImages.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/subscriptions","path_regex":"^(?:/youtube/v3/subscriptions)$","service_name":"google.youtube","resource_name":"youtube.subscriptions.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.delete"},{"hostname":"youtube.googleapis.com","http_method":"DELETE","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.delete"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/activities","path_regex":"^(?:/youtube/v3/activities)$","service_name":"google.youtube","resource_name":"youtube.activities.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/captions/{id}","path_regex":"^(?:/youtube/v3/captions/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtube","resource_name":"youtube.captions.download"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/channels","path_regex":"^(?:/youtube/v3/channels)$","service_name":"google.youtube","resource_name":"youtube.channels.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/commentThreads","path_regex":"^(?:/youtube/v3/commentThreads)$","service_name":"google.youtube","resource_name":"youtube.commentThreads.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/i18nLanguages","path_regex":"^(?:/youtube/v3/i18nLanguages)$","service_name":"google.youtube","resource_name":"youtube.i18nLanguages.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/i18nRegions","path_regex":"^(?:/youtube/v3/i18nRegions)$","service_name":"google.youtube","resource_name":"youtube.i18nRegions.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveChat/messages","path_regex":"^(?:/youtube/v3/liveChat/messages)$","service_name":"google.youtube","resource_name":"youtube.liveChatMessages.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveChat/moderators","path_regex":"^(?:/youtube/v3/liveChat/moderators)$","service_name":"google.youtube","resource_name":"youtube.liveChatModerators.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/members","path_regex":"^(?:/youtube/v3/members)$","service_name":"google.youtube","resource_name":"youtube.members.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/membershipsLevels","path_regex":"^(?:/youtube/v3/membershipsLevels)$","service_name":"google.youtube","resource_name":"youtube.membershipsLevels.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/playlistImages","path_regex":"^(?:/youtube/v3/playlistImages)$","service_name":"google.youtube","resource_name":"youtube.playlistImages.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/search","path_regex":"^(?:/youtube/v3/search)$","service_name":"google.youtube","resource_name":"youtube.search.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/subscriptions","path_regex":"^(?:/youtube/v3/subscriptions)$","service_name":"google.youtube","resource_name":"youtube.subscriptions.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/superChatEvents","path_regex":"^(?:/youtube/v3/superChatEvents)$","service_name":"google.youtube","resource_name":"youtube.superChatEvents.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videoAbuseReportReasons","path_regex":"^(?:/youtube/v3/videoAbuseReportReasons)$","service_name":"google.youtube","resource_name":"youtube.videoAbuseReportReasons.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videoCategories","path_regex":"^(?:/youtube/v3/videoCategories)$","service_name":"google.youtube","resource_name":"youtube.videoCategories.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.list"},{"hostname":"youtube.googleapis.com","http_method":"GET","path_template":"/youtube/v3/videos/getRating","path_regex":"^(?:/youtube/v3/videos/getRating)$","service_name":"google.youtube","resource_name":"youtube.videos.getRating"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/abuseReports","path_regex":"^(?:/youtube/v3/abuseReports)$","service_name":"google.youtube","resource_name":"youtube.abuseReports.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/channelBanners/insert","path_regex":"^(?:/youtube/v3/channelBanners/insert)$","service_name":"google.youtube","resource_name":"youtube.channelBanners.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/commentThreads","path_regex":"^(?:/youtube/v3/commentThreads)$","service_name":"google.youtube","resource_name":"youtube.commentThreads.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/comments/markAsSpam","path_regex":"^(?:/youtube/v3/comments/markAsSpam)$","service_name":"google.youtube","resource_name":"youtube.comments.markAsSpam"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/comments/setModerationStatus","path_regex":"^(?:/youtube/v3/comments/setModerationStatus)$","service_name":"google.youtube","resource_name":"youtube.comments.setModerationStatus"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts/bind","path_regex":"^(?:/youtube/v3/liveBroadcasts/bind)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.bind"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts/cuepoint","path_regex":"^(?:/youtube/v3/liveBroadcasts/cuepoint)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.insertCuepoint"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveBroadcasts/transition","path_regex":"^(?:/youtube/v3/liveBroadcasts/transition)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.transition"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveChat/bans","path_regex":"^(?:/youtube/v3/liveChat/bans)$","service_name":"google.youtube","resource_name":"youtube.liveChatBans.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveChat/messages","path_regex":"^(?:/youtube/v3/liveChat/messages)$","service_name":"google.youtube","resource_name":"youtube.liveChatMessages.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveChat/messages/transition","path_regex":"^(?:/youtube/v3/liveChat/messages/transition)$","service_name":"google.youtube","resource_name":"youtube.liveChatMessages.transition"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveChat/moderators","path_regex":"^(?:/youtube/v3/liveChat/moderators)$","service_name":"google.youtube","resource_name":"youtube.liveChatModerators.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/playlistImages","path_regex":"^(?:/youtube/v3/playlistImages)$","service_name":"google.youtube","resource_name":"youtube.playlistImages.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/subscriptions","path_regex":"^(?:/youtube/v3/subscriptions)$","service_name":"google.youtube","resource_name":"youtube.subscriptions.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/tests","path_regex":"^(?:/youtube/v3/tests)$","service_name":"google.youtube","resource_name":"youtube.tests.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/thumbnails/set","path_regex":"^(?:/youtube/v3/thumbnails/set)$","service_name":"google.youtube","resource_name":"youtube.thumbnails.set"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.insert"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/videos/rate","path_regex":"^(?:/youtube/v3/videos/rate)$","service_name":"google.youtube","resource_name":"youtube.videos.rate"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/videos/reportAbuse","path_regex":"^(?:/youtube/v3/videos/reportAbuse)$","service_name":"google.youtube","resource_name":"youtube.videos.reportAbuse"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/watermarks/set","path_regex":"^(?:/youtube/v3/watermarks/set)$","service_name":"google.youtube","resource_name":"youtube.watermarks.set"},{"hostname":"youtube.googleapis.com","http_method":"POST","path_template":"/youtube/v3/watermarks/unset","path_regex":"^(?:/youtube/v3/watermarks/unset)$","service_name":"google.youtube","resource_name":"youtube.watermarks.unset"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/captions","path_regex":"^(?:/youtube/v3/captions)$","service_name":"google.youtube","resource_name":"youtube.captions.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/channelSections","path_regex":"^(?:/youtube/v3/channelSections)$","service_name":"google.youtube","resource_name":"youtube.channelSections.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/channels","path_regex":"^(?:/youtube/v3/channels)$","service_name":"google.youtube","resource_name":"youtube.channels.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/commentThreads","path_regex":"^(?:/youtube/v3/commentThreads)$","service_name":"google.youtube","resource_name":"youtube.youtube.v3.updateCommentThreads"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/comments","path_regex":"^(?:/youtube/v3/comments)$","service_name":"google.youtube","resource_name":"youtube.comments.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/liveBroadcasts","path_regex":"^(?:/youtube/v3/liveBroadcasts)$","service_name":"google.youtube","resource_name":"youtube.liveBroadcasts.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/liveStreams","path_regex":"^(?:/youtube/v3/liveStreams)$","service_name":"google.youtube","resource_name":"youtube.liveStreams.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/playlistImages","path_regex":"^(?:/youtube/v3/playlistImages)$","service_name":"google.youtube","resource_name":"youtube.playlistImages.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/playlistItems","path_regex":"^(?:/youtube/v3/playlistItems)$","service_name":"google.youtube","resource_name":"youtube.playlistItems.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/playlists","path_regex":"^(?:/youtube/v3/playlists)$","service_name":"google.youtube","resource_name":"youtube.playlists.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/thirdPartyLinks","path_regex":"^(?:/youtube/v3/thirdPartyLinks)$","service_name":"google.youtube","resource_name":"youtube.thirdPartyLinks.update"},{"hostname":"youtube.googleapis.com","http_method":"PUT","path_template":"/youtube/v3/videos","path_regex":"^(?:/youtube/v3/videos)$","service_name":"google.youtube","resource_name":"youtube.videos.update"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"DELETE","path_template":"/v2/groupItems","path_regex":"^(?:/v2/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.delete"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"DELETE","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.delete"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"GET","path_template":"/v2/groupItems","path_regex":"^(?:/v2/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.list"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"GET","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.list"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"GET","path_template":"/v2/reports","path_regex":"^(?:/v2/reports)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.reports.query"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"POST","path_template":"/v2/groupItems","path_regex":"^(?:/v2/groupItems)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groupItems.insert"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"POST","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.insert"},{"hostname":"youtubeanalytics.googleapis.com","http_method":"PUT","path_template":"/v2/groups","path_regex":"^(?:/v2/groups)$","service_name":"google.youtubeAnalytics","resource_name":"youtubeAnalytics.groups.update"},{"hostname":"youtubereporting.googleapis.com","http_method":"DELETE","path_template":"/v1/jobs/{jobId}","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.delete"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs","path_regex":"^(?:/v1/jobs)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.list"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs/{jobId}","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.get"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs/{jobId}/reports","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.reports.list"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/jobs/{jobId}/reports/{reportId}","path_regex":"^(?:/v1/jobs/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?(?:/reports/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.reports.get"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/media/{mediaId}","path_regex":"^(?:/v1/media/)((?:(?:[\\x2c\\x2d\\x2e\\x30-\\x39\\x41-\\x5a\\x5f\\x61-\\x7a\\x7e]|%[[:xdigit:]][[:xdigit:]])*))?$","service_name":"google.youtubereporting","resource_name":"youtubereporting.media.download"},{"hostname":"youtubereporting.googleapis.com","http_method":"GET","path_template":"/v1/reportTypes","path_regex":"^(?:/v1/reportTypes)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.reportTypes.list"},{"hostname":"youtubereporting.googleapis.com","http_method":"POST","path_template":"/v1/jobs","path_regex":"^(?:/v1/jobs)$","service_name":"google.youtubereporting","resource_name":"youtubereporting.jobs.create"}] \ No newline at end of file diff --git a/contrib/google.golang.org/api/internal/gen_endpoints/main.go b/contrib/google.golang.org/api/internal/gen_endpoints/main.go index 148761d009..5a32360734 100644 --- a/contrib/google.golang.org/api/internal/gen_endpoints/main.go +++ b/contrib/google.golang.org/api/internal/gen_endpoints/main.go @@ -14,7 +14,6 @@ import ( "encoding/json" "flag" "fmt" - "github.com/yosida95/uritemplate/v3" "io" "log" "net/http" @@ -24,11 +23,13 @@ import ( "path/filepath" "sort" "strings" + + "github.com/yosida95/uritemplate/v3" ) const ( // The github.com/googleapis/google-api-go-client version to use. - version = "v0.121.0" + version = "v0.192.0" ) var ( diff --git a/go.mod b/go.mod index a90509a903..202960a3ce 100644 --- a/go.mod +++ b/go.mod @@ -5,7 +5,7 @@ go 1.22.0 toolchain go1.22.5 require ( - cloud.google.com/go/pubsub v1.36.1 + cloud.google.com/go/pubsub v1.40.0 github.com/99designs/gqlgen v0.17.36 github.com/DataDog/appsec-internal-go v1.7.0 github.com/DataDog/datadog-agent/pkg/obfuscate v0.57.0-rc.1 @@ -102,12 +102,12 @@ require ( go.uber.org/atomic v1.11.0 golang.org/x/mod v0.20.0 golang.org/x/net v0.27.0 - golang.org/x/oauth2 v0.18.0 + golang.org/x/oauth2 v0.22.0 golang.org/x/sys v0.23.0 golang.org/x/time v0.6.0 golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 - google.golang.org/api v0.169.0 - google.golang.org/grpc v1.64.0 + google.golang.org/api v0.192.0 + google.golang.org/grpc v1.64.1 google.golang.org/protobuf v1.34.2 gopkg.in/jinzhu/gorm.v1 v1.9.2 gopkg.in/olivere/elastic.v3 v3.0.75 @@ -122,10 +122,11 @@ require ( ) require ( - cloud.google.com/go v0.112.1 // indirect - cloud.google.com/go/compute v1.25.1 // indirect - cloud.google.com/go/compute/metadata v0.2.3 // indirect - cloud.google.com/go/iam v1.1.6 // indirect + cloud.google.com/go v0.115.0 // indirect + cloud.google.com/go/auth v0.8.1 // indirect + cloud.google.com/go/auth/oauth2adapt v0.2.3 // indirect + cloud.google.com/go/compute/metadata v0.5.0 // indirect + cloud.google.com/go/iam v1.1.12 // indirect github.com/DataDog/datadog-agent/pkg/util/log v0.57.0-rc.1 // indirect github.com/DataDog/datadog-agent/pkg/util/scrubber v0.57.0-rc.1 // indirect github.com/DataDog/go-sqllexer v0.0.13 // indirect @@ -171,7 +172,7 @@ require ( github.com/gabriel-vasile/mimetype v1.4.2 // indirect github.com/gin-contrib/sse v0.1.0 // indirect github.com/go-jose/go-jose/v3 v3.0.3 // indirect - github.com/go-logr/logr v1.4.1 // indirect + github.com/go-logr/logr v1.4.2 // indirect github.com/go-logr/stdr v1.2.2 // indirect github.com/go-ole/go-ole v1.2.6 // indirect github.com/go-openapi/jsonpointer v0.19.5 // indirect @@ -191,9 +192,9 @@ require ( github.com/google/gnostic v0.5.7-v3refs // indirect github.com/google/go-cmp v0.6.0 // indirect github.com/google/gofuzz v1.2.0 // indirect - github.com/google/s2a-go v0.1.7 // indirect + github.com/google/s2a-go v0.1.8 // indirect github.com/googleapis/enterprise-certificate-proxy v0.3.2 // indirect - github.com/googleapis/gax-go/v2 v2.12.2 // indirect + github.com/googleapis/gax-go/v2 v2.13.0 // indirect github.com/gorilla/websocket v1.5.0 // indirect github.com/hailocab/go-hostpool v0.0.0-20160125115350-e80d13ce29ed // indirect github.com/hashicorp/errwrap v1.1.0 // indirect @@ -278,7 +279,7 @@ require ( github.com/xdg-go/stringprep v1.0.4 // indirect github.com/youmark/pkcs8 v0.0.0-20181117223130-1be2e3e5546d // indirect github.com/yusufpapurcu/wmi v1.2.4 // indirect - go.einride.tech/aip v0.66.0 // indirect + go.einride.tech/aip v0.67.1 // indirect go.opencensus.io v0.24.0 // indirect go.opentelemetry.io/collector/component v0.104.0 // indirect go.opentelemetry.io/collector/config/configtelemetry v0.104.0 // indirect @@ -296,10 +297,9 @@ require ( golang.org/x/term v0.22.0 // indirect golang.org/x/text v0.16.0 // indirect golang.org/x/tools v0.23.0 // indirect - google.golang.org/appengine v1.6.8 // indirect - google.golang.org/genproto v0.0.0-20240213162025-012b6fc9bca9 // indirect - google.golang.org/genproto/googleapis/api v0.0.0-20240318140521-94a12d6c2237 // indirect - google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 // indirect + google.golang.org/genproto v0.0.0-20240730163845-b1a4ccb954bf // indirect + google.golang.org/genproto/googleapis/api v0.0.0-20240725223205-93522f1f2a9f // indirect + google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf // indirect gopkg.in/inf.v0 v0.9.1 // indirect gopkg.in/ini.v1 v1.67.0 // indirect gopkg.in/yaml.v2 v2.4.0 // indirect diff --git a/go.sum b/go.sum index 82a2473ddd..6616ecb551 100644 --- a/go.sum +++ b/go.sum @@ -38,8 +38,8 @@ cloud.google.com/go v0.104.0/go.mod h1:OO6xxXdJyvuJPcEPBLN9BJPD+jep5G1+2U5B5gkRY cloud.google.com/go v0.105.0/go.mod h1:PrLgOJNe5nfE9UMxKxgXj4mD3voiP+YQ6gdt6KMFOKM= cloud.google.com/go v0.107.0/go.mod h1:wpc2eNrD7hXUTy8EKS10jkxpZBjASrORK7goS+3YX2I= cloud.google.com/go v0.110.0/go.mod h1:SJnCLqQ0FCFGSZMUNUf84MV3Aia54kn7pi8st7tMzaY= -cloud.google.com/go v0.112.1 h1:uJSeirPke5UNZHIb4SxfZklVSiWWVqW4oXlETwZziwM= -cloud.google.com/go v0.112.1/go.mod h1:+Vbu+Y1UU+I1rjmzeMOb/8RfkKJK2Gyxi1X6jJCZLo4= +cloud.google.com/go v0.115.0 h1:CnFSK6Xo3lDYRoBKEcAtia6VSC837/ZkJuRduSFnr14= +cloud.google.com/go v0.115.0/go.mod h1:8jIM5vVgoAEoiVxQ/O4BFTfHqulPZgs/ufEzMcFMdWU= cloud.google.com/go/accessapproval v1.4.0/go.mod h1:zybIuC3KpDOvotz59lFe5qxRZx6C75OtwbisN56xYB4= cloud.google.com/go/accessapproval v1.5.0/go.mod h1:HFy3tuiGvMdcd/u+Cu5b9NkO1pEICJ46IR82PoUdplw= cloud.google.com/go/accessapproval v1.6.0/go.mod h1:R0EiYnwV5fsRFiKZkPHr6mwyk2wxUJ30nL4j2pcFY2E= @@ -97,6 +97,10 @@ cloud.google.com/go/assuredworkloads v1.7.0/go.mod h1:z/736/oNmtGAyU47reJgGN+KVo cloud.google.com/go/assuredworkloads v1.8.0/go.mod h1:AsX2cqyNCOvEQC8RMPnoc0yEarXQk6WEKkxYfL6kGIo= cloud.google.com/go/assuredworkloads v1.9.0/go.mod h1:kFuI1P78bplYtT77Tb1hi0FMxM0vVpRC7VVoJC3ZoT0= cloud.google.com/go/assuredworkloads v1.10.0/go.mod h1:kwdUQuXcedVdsIaKgKTp9t0UJkE5+PAVNhdQm4ZVq2E= +cloud.google.com/go/auth v0.8.1 h1:QZW9FjC5lZzN864p13YxvAtGUlQ+KgRL+8Sg45Z6vxo= +cloud.google.com/go/auth v0.8.1/go.mod h1:qGVp/Y3kDRSDZ5gFD/XPUfYQ9xW1iI7q8RIRoCyBbJc= +cloud.google.com/go/auth/oauth2adapt v0.2.3 h1:MlxF+Pd3OmSudg/b1yZ5lJwoXCEaeedAguodky1PcKI= +cloud.google.com/go/auth/oauth2adapt v0.2.3/go.mod h1:tMQXOfZzFuNuUxOypHlQEXgdfX5cuhwU+ffUuXRJE8I= cloud.google.com/go/automl v1.5.0/go.mod h1:34EjfoFGMZ5sgJ9EoLsRtdPSNZLcfflJR39VbVNS2M0= cloud.google.com/go/automl v1.6.0/go.mod h1:ugf8a6Fx+zP0D59WLhqgTDsQI9w07o64uf/Is3Nh5p8= cloud.google.com/go/automl v1.7.0/go.mod h1:RL9MYCCsJEOmt0Wf3z9uzG0a7adTT1fe+aObgSpkCt8= @@ -170,13 +174,12 @@ cloud.google.com/go/compute v1.14.0/go.mod h1:YfLtxrj9sU4Yxv+sXzZkyPjEyPBZfXHUvj cloud.google.com/go/compute v1.15.1/go.mod h1:bjjoF/NtFUrkD/urWfdHaKuOPDR5nWIs63rR+SXhcpA= cloud.google.com/go/compute v1.18.0/go.mod h1:1X7yHxec2Ga+Ss6jPyjxRxpu2uu7PLgsOVXvgU0yacs= cloud.google.com/go/compute v1.19.0/go.mod h1:rikpw2y+UMidAe9tISo04EHNOIf42RLYF/q8Bs93scU= -cloud.google.com/go/compute v1.25.1 h1:ZRpHJedLtTpKgr3RV1Fx23NuaAEN1Zfx9hw1u4aJdjU= -cloud.google.com/go/compute v1.25.1/go.mod h1:oopOIR53ly6viBYxaDhBfJwzUAxf1zE//uf3IB011ls= cloud.google.com/go/compute/metadata v0.1.0/go.mod h1:Z1VN+bulIf6bt4P/C37K4DyZYZEXYonfTBHHFPO/4UU= cloud.google.com/go/compute/metadata v0.2.0/go.mod h1:zFmK7XCadkQkj6TtorcaGlCW1hT1fIilQDwofLpJ20k= cloud.google.com/go/compute/metadata v0.2.1/go.mod h1:jgHgmJd2RKBGzXqF5LR2EZMGxBkeanZ9wwa75XHJgOM= -cloud.google.com/go/compute/metadata v0.2.3 h1:mg4jlk7mCAj6xXp9UJ4fjI9VUI5rubuGBW5aJ7UnBMY= cloud.google.com/go/compute/metadata v0.2.3/go.mod h1:VAV5nSsACxMJvgaAuX6Pk2AawlZn8kiOGuCv6gTkwuA= +cloud.google.com/go/compute/metadata v0.5.0 h1:Zr0eK8JbFv6+Wi4ilXAR8FJ3wyNdpxHKJNPos6LTZOY= +cloud.google.com/go/compute/metadata v0.5.0/go.mod h1:aHnloV2TPI38yx4s9+wAZhHykWvVCfu7hQbF+9CWoiY= cloud.google.com/go/contactcenterinsights v1.3.0/go.mod h1:Eu2oemoePuEFc/xKFPjbTuPSj0fYJcPls9TFlPNnHHY= cloud.google.com/go/contactcenterinsights v1.4.0/go.mod h1:L2YzkGbPsv+vMQMCADxJoT9YiTTnSEd6fEvCeHTYVck= cloud.google.com/go/contactcenterinsights v1.6.0/go.mod h1:IIDlT6CLcDoyv79kDv8iWxMSTZhLxSCofVV5W6YFM/w= @@ -308,8 +311,8 @@ cloud.google.com/go/iam v0.8.0/go.mod h1:lga0/y3iH6CX7sYqypWJ33hf7kkfXJag67naqGE cloud.google.com/go/iam v0.11.0/go.mod h1:9PiLDanza5D+oWFZiH1uG+RnRCfEGKoyl6yo4cgWZGY= cloud.google.com/go/iam v0.12.0/go.mod h1:knyHGviacl11zrtZUoDuYpDgLjvr28sLQaG0YB2GYAY= cloud.google.com/go/iam v0.13.0/go.mod h1:ljOg+rcNfzZ5d6f1nAUJ8ZIxOaZUVoS14bKCtaLZ/D0= -cloud.google.com/go/iam v1.1.6 h1:bEa06k05IO4f4uJonbB5iAgKTPpABy1ayxaIZV/GHVc= -cloud.google.com/go/iam v1.1.6/go.mod h1:O0zxdPeGBoFdWW3HWmBxJsk0pfvNM/p/qa82rWOGTwI= +cloud.google.com/go/iam v1.1.12 h1:JixGLimRrNGcxvJEQ8+clfLxPlbeZA6MuRJ+qJNQ5Xw= +cloud.google.com/go/iam v1.1.12/go.mod h1:9LDX8J7dN5YRyzVHxwQzrQs9opFFqn0Mxs9nAeB+Hhg= cloud.google.com/go/iap v1.4.0/go.mod h1:RGFwRJdihTINIe4wZ2iCP0zF/qu18ZwyKxrhMhygBEc= cloud.google.com/go/iap v1.5.0/go.mod h1:UH/CGgKd4KyohZL5Pt0jSKE4m3FR51qg6FKQ/z/Ix9A= cloud.google.com/go/iap v1.6.0/go.mod h1:NSuvI9C/j7UdjGjIde7t7HBz+QTwBcapPE07+sSRcLk= @@ -327,8 +330,8 @@ cloud.google.com/go/kms v1.6.0/go.mod h1:Jjy850yySiasBUDi6KFUwUv2n1+o7QZFyuUJg6O cloud.google.com/go/kms v1.8.0/go.mod h1:4xFEhYFqvW+4VMELtZyxomGSYtSQKzM178ylFW4jMAg= cloud.google.com/go/kms v1.9.0/go.mod h1:qb1tPTgfF9RQP8e1wq4cLFErVuTJv7UsSC915J8dh3w= cloud.google.com/go/kms v1.10.0/go.mod h1:ng3KTUtQQU9bPX3+QGLsflZIHlkbn8amFAMY63m8d24= -cloud.google.com/go/kms v1.15.7 h1:7caV9K3yIxvlQPAcaFffhlT7d1qpxjB1wHBtjWa13SM= -cloud.google.com/go/kms v1.15.7/go.mod h1:ub54lbsa6tDkUwnu4W7Yt1aAIFLnspgh0kPGToDukeI= +cloud.google.com/go/kms v1.18.4 h1:dYN3OCsQ6wJLLtOnI8DGUwQ5shMusXsWCCC+s09ATsk= +cloud.google.com/go/kms v1.18.4/go.mod h1:SG1bgQ3UWW6/KdPo9uuJnzELXY5YTTMJtDYvajiQ22g= cloud.google.com/go/language v1.4.0/go.mod h1:F9dRpNFQmJbkaop6g0JhSBXCNlO90e1KWx5iDdxbWic= cloud.google.com/go/language v1.6.0/go.mod h1:6dJ8t3B+lUYfStgls25GusK04NLh3eDLQnWM3mdEbhI= cloud.google.com/go/language v1.7.0/go.mod h1:DJ6dYN/W+SQOjF8e1hLQXMF21AkH2w9wiPzPCJa2MIE= @@ -342,6 +345,8 @@ cloud.google.com/go/logging v1.7.0/go.mod h1:3xjP2CjkM3ZkO73aj4ASA5wRPGGCRrPIAeN cloud.google.com/go/longrunning v0.1.1/go.mod h1:UUFxuDWkv22EuY93jjmDMFT5GPQKeFVJBIF6QlTqdsE= cloud.google.com/go/longrunning v0.3.0/go.mod h1:qth9Y41RRSUE69rDcOn6DdK3HfQfsUI0YSmW3iIlLJc= cloud.google.com/go/longrunning v0.4.1/go.mod h1:4iWDqhBZ70CvZ6BfETbvam3T8FMvLK+eFj0E6AaRQTo= +cloud.google.com/go/longrunning v0.5.11 h1:Havn1kGjz3whCfoD8dxMLP73Ph5w+ODyZB9RUsDxtGk= +cloud.google.com/go/longrunning v0.5.11/go.mod h1:rDn7//lmlfWV1Dx6IB4RatCPenTwwmqXuiP0/RgoEO4= cloud.google.com/go/managedidentities v1.3.0/go.mod h1:UzlW3cBOiPrzucO5qWkNkh0w33KFtBJU281hacNvsdE= cloud.google.com/go/managedidentities v1.4.0/go.mod h1:NWSBYbEMgqmbZsLIyKvxrYbtqOsxY1ZrGM+9RgDqInM= cloud.google.com/go/managedidentities v1.5.0/go.mod h1:+dWcZ0JlUmpuxpIDfyP5pP5y0bLdRwOS4Lp7gMni/LA= @@ -422,8 +427,8 @@ cloud.google.com/go/pubsub v1.26.0/go.mod h1:QgBH3U/jdJy/ftjPhTkyXNj543Tin1pRYcd cloud.google.com/go/pubsub v1.27.1/go.mod h1:hQN39ymbV9geqBnfQq6Xf63yNhUAhv9CZhzp5O6qsW0= cloud.google.com/go/pubsub v1.28.0/go.mod h1:vuXFpwaVoIPQMGXqRyUQigu/AX1S3IWugR9xznmcXX8= cloud.google.com/go/pubsub v1.30.0/go.mod h1:qWi1OPS0B+b5L+Sg6Gmc9zD1Y+HaM0MdUr7LsupY1P4= -cloud.google.com/go/pubsub v1.36.1 h1:dfEPuGCHGbWUhaMCTHUFjfroILEkx55iUmKBZTP5f+Y= -cloud.google.com/go/pubsub v1.36.1/go.mod h1:iYjCa9EzWOoBiTdd4ps7QoMtMln5NwaZQpK1hbRfBDE= +cloud.google.com/go/pubsub v1.40.0 h1:0LdP+zj5XaPAGtWr2V6r88VXJlmtaB/+fde1q3TU8M0= +cloud.google.com/go/pubsub v1.40.0/go.mod h1:BVJI4sI2FyXp36KFKvFwcfDRDfR8MiLT8mMhmIhdAeA= cloud.google.com/go/pubsublite v1.5.0/go.mod h1:xapqNQ1CuLfGi23Yda/9l4bBCKz/wC3KIJ5gKcxveZg= cloud.google.com/go/pubsublite v1.6.0/go.mod h1:1eFCS0U11xlOuMFV/0iBqw3zP12kddMeCbj/F3FSj9k= cloud.google.com/go/pubsublite v1.7.0/go.mod h1:8hVMwRXfDfvGm3fahVbtDbiLePT3gpoiJYJY+vxWxVM= @@ -1193,8 +1198,8 @@ github.com/go-logr/logr v1.2.0/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbV github.com/go-logr/logr v1.2.1/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= github.com/go-logr/logr v1.2.2/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= github.com/go-logr/logr v1.2.3/go.mod h1:jdQByPbusPIv2/zmleS9BjJVeZ6kBagPoEUsqbVz/1A= -github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= -github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= +github.com/go-logr/logr v1.4.2 h1:6pFjapn8bFcIbiKo3XT4j/BhANplGihG6tvd+8rYgrY= +github.com/go-logr/logr v1.4.2/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= github.com/go-logr/stdr v1.2.0/go.mod h1:YkVgnZu1ZjjL7xTxrfm/LLZBfkhTqSR1ydtm6jTKKwI= github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= @@ -1377,8 +1382,8 @@ github.com/google/pprof v0.0.0-20211008130755-947d60d73cc0/go.mod h1:KgnwoLYCZ8I github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b h1:h9U78+dx9a4BKdQkBBos92HalKpaGKHrp+3Uo6yTodo= github.com/google/pprof v0.0.0-20230817174616-7a8ec2ada47b/go.mod h1:czg5+yv1E0ZGTi6S6vVK1mke0fV+FaUhNGcd6VRS9Ik= github.com/google/renameio v0.1.0/go.mod h1:KWCgfxg9yswjAJkECMjeO8J8rahYeXnNhOm40UhjYkI= -github.com/google/s2a-go v0.1.7 h1:60BLSyTrOV4/haCDW4zb1guZItoSq8foHCXrAnjBo/o= -github.com/google/s2a-go v0.1.7/go.mod h1:50CgR4k1jNlWBu4UfS4AcfhVe1r6pdZPygJ3R8F0Qdw= +github.com/google/s2a-go v0.1.8 h1:zZDs9gcbt9ZPLV0ndSyQk6Kacx2g/X+SKYovpnz3SMM= +github.com/google/s2a-go v0.1.8/go.mod h1:6iNWHTpQ+nfNRN5E00MSdfDwVesa8hhS32PhPO8deJA= github.com/google/shlex v0.0.0-20191202100458-e7afc7fbc510/go.mod h1:pupxD2MaaD3pAXIBCelhxNneeOaAeabZDe5s4K6zSpQ= github.com/google/uuid v1.0.0/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= github.com/google/uuid v1.1.1/go.mod h1:TIyPZe4MgqvfeYDBFedMoGGpEw/LqOeaOT+nhxU+yHo= @@ -1405,8 +1410,8 @@ github.com/googleapis/gax-go/v2 v2.5.1/go.mod h1:h6B0KMMFNtI2ddbGJn3T3ZbwkeT6yqE github.com/googleapis/gax-go/v2 v2.6.0/go.mod h1:1mjbznJAPHFpesgE5ucqfYEscaz5kMdcIDwU/6+DDoY= github.com/googleapis/gax-go/v2 v2.7.0/go.mod h1:TEop28CZZQ2y+c0VxMUmu1lV+fQx57QpBWsYpwqHJx8= github.com/googleapis/gax-go/v2 v2.7.1/go.mod h1:4orTrqY6hXxxaUL4LHIPl6lGo8vAE38/qKbhSAKP6QI= -github.com/googleapis/gax-go/v2 v2.12.2 h1:mhN09QQW1jEWeMF74zGR81R30z4VJzjZsfkUhuHF+DA= -github.com/googleapis/gax-go/v2 v2.12.2/go.mod h1:61M8vcyyXR2kqKFxKrfA22jaA8JGF7Dc8App1U3H6jc= +github.com/googleapis/gax-go/v2 v2.13.0 h1:yitjD5f7jQHhyDsnhKEBU52NdvvdSeGzlAnDPT0hH1s= +github.com/googleapis/gax-go/v2 v2.13.0/go.mod h1:Z/fvTZXF8/uw7Xu5GuslPw+bplx6SS338j1Is2S+B7A= github.com/googleapis/gnostic v0.4.1/go.mod h1:LRhVm6pbyptWbWbuZ38d1eyptfvIytN3ir6b65WBswg= github.com/googleapis/gnostic v0.5.1/go.mod h1:6U4PtQXGIEt/Z3h5MAT7FNofLnw9vXk2cUuW7uA/OeU= github.com/googleapis/gnostic v0.5.5/go.mod h1:7+EbHbldMins07ALC74bsA81Ovc97DwqyJO1AENw9kA= @@ -2175,8 +2180,8 @@ github.com/zeebo/assert v1.3.0/go.mod h1:Pq9JiuJQpG8JLJdtkwrJESF0Foym2/D9XMU5ciN github.com/zeebo/xxh3 v1.0.2/go.mod h1:5NWz9Sef7zIDm2JHfFlcQvNekmcEl9ekUZQQKCYaDcA= github.com/zenazn/goji v1.0.1 h1:4lbD8Mx2h7IvloP7r2C0D6ltZP6Ufip8Hn0wmSK5LR8= github.com/zenazn/goji v1.0.1/go.mod h1:7S9M489iMyHBNxwZnk9/EHS098H4/F6TATF2mIxtB1Q= -go.einride.tech/aip v0.66.0 h1:XfV+NQX6L7EOYK11yoHHFtndeaWh3KbD9/cN/6iWEt8= -go.einride.tech/aip v0.66.0/go.mod h1:qAhMsfT7plxBX+Oy7Huol6YUvZ0ZzdUz26yZsQwfl1M= +go.einride.tech/aip v0.67.1 h1:d/4TW92OxXBngkSOwWS2CH5rez869KpKMaN44mdxkFI= +go.einride.tech/aip v0.67.1/go.mod h1:ZGX4/zKw8dcgzdLsrvpOOGxfxI2QSk12SlP7d6c0/XI= go.etcd.io/bbolt v1.3.2/go.mod h1:IbVyRI1SCnLcuJnV2u8VeU0CEYM7e686BmAb1XKL+uU= go.etcd.io/bbolt v1.3.3/go.mod h1:IbVyRI1SCnLcuJnV2u8VeU0CEYM7e686BmAb1XKL+uU= go.etcd.io/bbolt v1.3.5/go.mod h1:G5EMThwa9y8QZGBClrRx5EY+Yw9kAhnjy3bSjsnlVTQ= @@ -2481,8 +2486,8 @@ golang.org/x/oauth2 v0.0.0-20221014153046-6fdb5e3db783/go.mod h1:h4gKUeWbJ4rQPri golang.org/x/oauth2 v0.4.0/go.mod h1:RznEsdpjGAINPTOF0UH/t+xJ75L18YO3Ho6Pyn+uRec= golang.org/x/oauth2 v0.5.0/go.mod h1:9/XBHVqLaWO3/BRHs5jbpYCnOZVjj5V0ndyaAM7KB4I= golang.org/x/oauth2 v0.6.0/go.mod h1:ycmewcwgD4Rpr3eZJLSB4Kyyljb3qDh40vJ8STE5HKw= -golang.org/x/oauth2 v0.18.0 h1:09qnuIAgzdx1XplqJvW6CQqMCtGZykZWcXzPMPUusvI= -golang.org/x/oauth2 v0.18.0/go.mod h1:Wf7knwG0MPoWIMMBgFlEaSUDaKskp0dCfrlJRJXbBi8= +golang.org/x/oauth2 v0.22.0 h1:BzDx2FehcG7jJwgWLELCdmLuxk2i+x9UDpSiss2u0ZA= +golang.org/x/oauth2 v0.22.0/go.mod h1:XYTD2NtWslqkgxebSiOHnXEap4TF09sJSc7H1sXbhtI= golang.org/x/sync v0.0.0-20180314180146-1d60e4601c6f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20181108010431-42b317875d0f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20181221193216-37e7f081c4d4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= @@ -2856,8 +2861,8 @@ google.golang.org/api v0.108.0/go.mod h1:2Ts0XTHNVWxypznxWOYUeI4g3WdP9Pk2Qk58+a/ google.golang.org/api v0.110.0/go.mod h1:7FC4Vvx1Mooxh8C5HWjzZHcavuS2f6pmJpZx60ca7iI= google.golang.org/api v0.111.0/go.mod h1:qtFHvU9mhgTJegR31csQ+rwxyUTHOKFqCKWp1J0fdw0= google.golang.org/api v0.114.0/go.mod h1:ifYI2ZsFK6/uGddGfAD5BMxlnkBqCmqHSDUVi45N5Yg= -google.golang.org/api v0.169.0 h1:QwWPy71FgMWqJN/l6jVlFHUa29a7dcUy02I8o799nPY= -google.golang.org/api v0.169.0/go.mod h1:gpNOiMA2tZ4mf5R9Iwf4rK/Dcz0fbdIgWYWVoxmsyLg= +google.golang.org/api v0.192.0 h1:PljqpNAfZaaSpS+TnANfnNAXKdzHM/B9bKhwRlo7JP0= +google.golang.org/api v0.192.0/go.mod h1:9VcphjvAxPKLmSxVSzPlSRXy/5ARMEw5bf58WoVXafQ= google.golang.org/appengine v1.1.0/go.mod h1:EbEs0AVv82hx2wNQdGPgUI5lhzA/G0D9YwlJXL52JkM= google.golang.org/appengine v1.4.0/go.mod h1:xpcJRLb0r/rnEns0DIKYYv+WjYCduHsrkT7/EB5XEv4= google.golang.org/appengine v1.5.0/go.mod h1:xpcJRLb0r/rnEns0DIKYYv+WjYCduHsrkT7/EB5XEv4= @@ -3004,12 +3009,12 @@ google.golang.org/genproto v0.0.0-20230303212802-e74f57abe488/go.mod h1:TvhZT5f7 google.golang.org/genproto v0.0.0-20230306155012-7f2fa6fef1f4/go.mod h1:NWraEVixdDnqcqQ30jipen1STv2r/n24Wb7twVTGR4s= google.golang.org/genproto v0.0.0-20230320184635-7606e756e683/go.mod h1:NWraEVixdDnqcqQ30jipen1STv2r/n24Wb7twVTGR4s= google.golang.org/genproto v0.0.0-20230331144136-dcfb400f0633/go.mod h1:UUQDJDOlWu4KYeJZffbWgBkS1YFobzKbLVfK69pe0Ak= -google.golang.org/genproto v0.0.0-20240213162025-012b6fc9bca9 h1:9+tzLLstTlPTRyJTh+ah5wIMsBW5c4tQwGTN3thOW9Y= -google.golang.org/genproto v0.0.0-20240213162025-012b6fc9bca9/go.mod h1:mqHbVIp48Muh7Ywss/AD6I5kNVKZMmAa/QEW58Gxp2s= -google.golang.org/genproto/googleapis/api v0.0.0-20240318140521-94a12d6c2237 h1:RFiFrvy37/mpSpdySBDrUdipW/dHwsRwh3J3+A9VgT4= -google.golang.org/genproto/googleapis/api v0.0.0-20240318140521-94a12d6c2237/go.mod h1:Z5Iiy3jtmioajWHDGFk7CeugTyHtPvMHA4UTmUkyalE= -google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 h1:Q2RxlXqh1cgzzUgV261vBO2jI5R/3DD1J2pM0nI4NhU= -google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5/go.mod h1:EfXuqaE1J41VCDicxHzUDm+8rk+7ZdXzHV0IhO/I6s0= +google.golang.org/genproto v0.0.0-20240730163845-b1a4ccb954bf h1:OqdXDEakZCVtDiZTjcxfwbHPCT11ycCEsTKesBVKvyY= +google.golang.org/genproto v0.0.0-20240730163845-b1a4ccb954bf/go.mod h1:mCr1K1c8kX+1iSBREvU3Juo11CB+QOEWxbRS01wWl5M= +google.golang.org/genproto/googleapis/api v0.0.0-20240725223205-93522f1f2a9f h1:b1Ln/PG8orm0SsBbHZWke8dDp2lrCD4jSmfglFpTZbk= +google.golang.org/genproto/googleapis/api v0.0.0-20240725223205-93522f1f2a9f/go.mod h1:AHT0dDg3SoMOgZGnZk29b5xTbPHMoEC8qthmBLJCpys= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf h1:liao9UHurZLtiEwBgT9LMOnKYsHze6eA6w1KQCMVN2Q= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf/go.mod h1:Ue6ibwXGpU+dqIcODieyLOcgj7z8+IcskoNIgZxtrFY= google.golang.org/grpc v0.0.0-20160317175043-d3ddb4469d5a/go.mod h1:yo6s7OP7yaDglbqo1J04qKzAhqBH6lvTonzMVmEdcZw= google.golang.org/grpc v1.19.0/go.mod h1:mqu4LbDTu4XGKhr4mRzUsmM4RtVoemTSY81AxZiDr8c= google.golang.org/grpc v1.20.1/go.mod h1:10oTOabMzJvdu6/UiuZezV6QK5dSlG84ov/aaiqXj38= @@ -3054,8 +3059,8 @@ google.golang.org/grpc v1.50.1/go.mod h1:ZgQEeidpAuNRZ8iRrlBKXZQP1ghovWIVhdJRyCD google.golang.org/grpc v1.51.0/go.mod h1:wgNDFcnuBGmxLKI/qn4T+m5BtEBYXJPvibbUPsAIPww= google.golang.org/grpc v1.53.0/go.mod h1:OnIrk0ipVdj4N5d9IUoFUx72/VlD7+jUsHwZgwSMQpw= google.golang.org/grpc v1.54.0/go.mod h1:PUSEXI6iWghWaB6lXM4knEgpJNu2qUcKfDtNci3EC2g= -google.golang.org/grpc v1.64.0 h1:KH3VH9y/MgNQg1dE7b3XfVK0GsPSIzJwdF617gUSbvY= -google.golang.org/grpc v1.64.0/go.mod h1:oxjF8E3FBnjp+/gVFYdWacaLDx9na1aqy9oovLpxQYg= +google.golang.org/grpc v1.64.1 h1:LKtvyfbX3UGVPFcGqJ9ItpVWW6oN/2XqTxfAnwRRXiA= +google.golang.org/grpc v1.64.1/go.mod h1:hiQF4LFZelK2WKaP6W0L92zGHtiQdZxk8CrSdvyjeP0= google.golang.org/grpc/cmd/protoc-gen-go-grpc v1.1.0/go.mod h1:6Kw0yEErY5E/yWrBtf03jp27GLLJujG4z/JK95pnjjw= google.golang.org/protobuf v0.0.0-20200109180630-ec00e32a8dfd/go.mod h1:DFci5gLYBciE7Vtevhsrf46CRTquxDuWsQurQQe4oz8= google.golang.org/protobuf v0.0.0-20200221191635-4d8936d0db64/go.mod h1:kwYJMbMJ01Woi6D6+Kah6886xMZcty6N08ah7+eCXa0= diff --git a/internal/apps/go.mod b/internal/apps/go.mod index e882d5be3b..e6b43c7069 100644 --- a/internal/apps/go.mod +++ b/internal/apps/go.mod @@ -56,8 +56,8 @@ require ( golang.org/x/net v0.27.0 // indirect golang.org/x/text v0.16.0 // indirect golang.org/x/tools v0.23.0 // indirect - google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 // indirect - google.golang.org/grpc v1.64.0 // indirect + google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf // indirect + google.golang.org/grpc v1.64.1 // indirect gopkg.in/ini.v1 v1.67.0 // indirect gopkg.in/yaml.v2 v2.4.0 // indirect gopkg.in/yaml.v3 v3.0.1 // indirect diff --git a/internal/apps/go.sum b/internal/apps/go.sum index 4e9454e89c..44396179cb 100644 --- a/internal/apps/go.sum +++ b/internal/apps/go.sum @@ -55,8 +55,8 @@ github.com/ebitengine/purego v0.6.0-alpha.5/go.mod h1:ah1In8AOtksoNK6yk5z1HTJeUk github.com/fatih/color v1.7.0/go.mod h1:Zm6kSWBoL9eyXnKyktHP6abPY2pDugNf5KwzbycvMj4= github.com/glebarez/go-sqlite v1.22.0 h1:uAcMJhaA6r3LHMTFgP0SifzgXg46yJkgxqyuyec+ruQ= github.com/glebarez/go-sqlite v1.22.0/go.mod h1:PlBIdHe0+aUEFn+r2/uthrWq4FxbzugL0L8Li6yQJbc= -github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= -github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= +github.com/go-logr/logr v1.4.2 h1:6pFjapn8bFcIbiKo3XT4j/BhANplGihG6tvd+8rYgrY= +github.com/go-logr/logr v1.4.2/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= github.com/go-ole/go-ole v1.2.6 h1:/Fpf6oFPoeFik9ty7siob0G6Ke8QvQEuVcuChpwXzpY= @@ -297,10 +297,10 @@ golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 h1:+cNy6SZtPcJQH3LJVLOSm golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028/go.mod h1:NDW/Ps6MPRej6fsCIbMTohpP40sJ/P/vI1MoTEGwX90= google.golang.org/appengine v1.6.8 h1:IhEN5q69dyKagZPYMSdIjS2HqprW324FRQZJcGqPAsM= google.golang.org/appengine v1.6.8/go.mod h1:1jJ3jBArFh5pcgW8gCtRJnepW8FzD1V44FJffLiz/Ds= -google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 h1:Q2RxlXqh1cgzzUgV261vBO2jI5R/3DD1J2pM0nI4NhU= -google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5/go.mod h1:EfXuqaE1J41VCDicxHzUDm+8rk+7ZdXzHV0IhO/I6s0= -google.golang.org/grpc v1.64.0 h1:KH3VH9y/MgNQg1dE7b3XfVK0GsPSIzJwdF617gUSbvY= -google.golang.org/grpc v1.64.0/go.mod h1:oxjF8E3FBnjp+/gVFYdWacaLDx9na1aqy9oovLpxQYg= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf h1:liao9UHurZLtiEwBgT9LMOnKYsHze6eA6w1KQCMVN2Q= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf/go.mod h1:Ue6ibwXGpU+dqIcODieyLOcgj7z8+IcskoNIgZxtrFY= +google.golang.org/grpc v1.64.1 h1:LKtvyfbX3UGVPFcGqJ9ItpVWW6oN/2XqTxfAnwRRXiA= +google.golang.org/grpc v1.64.1/go.mod h1:hiQF4LFZelK2WKaP6W0L92zGHtiQdZxk8CrSdvyjeP0= google.golang.org/protobuf v1.26.0-rc.1/go.mod h1:jlhhOSvTdKEhbULTjvd4ARK9grFBp09yW+WbY/TyQbw= google.golang.org/protobuf v1.33.0/go.mod h1:c6P6GXX6sHbq/GpV6MGZEdwhWPcYBgnhAHhKbcUYpos= google.golang.org/protobuf v1.34.2 h1:6xV6lTsCfpGD21XK49h7MhtcApnLqkfYgPcdHftf6hg= diff --git a/internal/exectracetest/go.mod b/internal/exectracetest/go.mod index 51512728d2..674506bf90 100644 --- a/internal/exectracetest/go.mod +++ b/internal/exectracetest/go.mod @@ -67,8 +67,8 @@ require ( golang.org/x/time v0.6.0 // indirect golang.org/x/tools v0.23.0 // indirect golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 // indirect - google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 // indirect - google.golang.org/grpc v1.64.0 // indirect + google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf // indirect + google.golang.org/grpc v1.64.1 // indirect google.golang.org/protobuf v1.34.2 // indirect gopkg.in/ini.v1 v1.67.0 // indirect gopkg.in/yaml.v2 v2.4.0 // indirect diff --git a/internal/exectracetest/go.sum b/internal/exectracetest/go.sum index d670cc7125..45417773e7 100644 --- a/internal/exectracetest/go.sum +++ b/internal/exectracetest/go.sum @@ -55,8 +55,8 @@ github.com/ebitengine/purego v0.6.0-alpha.5 h1:EYID3JOAdmQ4SNZYJHu9V6IqOeRQDBYxq github.com/ebitengine/purego v0.6.0-alpha.5/go.mod h1:ah1In8AOtksoNK6yk5z1HTJeUkC1Ez4Wk2idgGslMwQ= github.com/glebarez/go-sqlite v1.22.0 h1:uAcMJhaA6r3LHMTFgP0SifzgXg46yJkgxqyuyec+ruQ= github.com/glebarez/go-sqlite v1.22.0/go.mod h1:PlBIdHe0+aUEFn+r2/uthrWq4FxbzugL0L8Li6yQJbc= -github.com/go-logr/logr v1.4.1 h1:pKouT5E8xu9zeFC39JXRDukb6JFQPXM5p5I91188VAQ= -github.com/go-logr/logr v1.4.1/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= +github.com/go-logr/logr v1.4.2 h1:6pFjapn8bFcIbiKo3XT4j/BhANplGihG6tvd+8rYgrY= +github.com/go-logr/logr v1.4.2/go.mod h1:9T104GzyrTigFIr8wt5mBrctHMim0Nb2HLGrmQ40KvY= github.com/go-logr/stdr v1.2.2 h1:hSWxHoqTgW2S2qGc0LTAI563KZ5YKYRhT3MFKZMbjag= github.com/go-logr/stdr v1.2.2/go.mod h1:mMo/vtBO5dYbehREoey6XUKy/eSumjCCveDpRre4VKE= github.com/go-ole/go-ole v1.2.6 h1:/Fpf6oFPoeFik9ty7siob0G6Ke8QvQEuVcuChpwXzpY= @@ -292,10 +292,10 @@ golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028 h1:+cNy6SZtPcJQH3LJVLOSm golang.org/x/xerrors v0.0.0-20231012003039-104605ab7028/go.mod h1:NDW/Ps6MPRej6fsCIbMTohpP40sJ/P/vI1MoTEGwX90= google.golang.org/appengine v1.6.8 h1:IhEN5q69dyKagZPYMSdIjS2HqprW324FRQZJcGqPAsM= google.golang.org/appengine v1.6.8/go.mod h1:1jJ3jBArFh5pcgW8gCtRJnepW8FzD1V44FJffLiz/Ds= -google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5 h1:Q2RxlXqh1cgzzUgV261vBO2jI5R/3DD1J2pM0nI4NhU= -google.golang.org/genproto/googleapis/rpc v0.0.0-20240520151616-dc85e6b867a5/go.mod h1:EfXuqaE1J41VCDicxHzUDm+8rk+7ZdXzHV0IhO/I6s0= -google.golang.org/grpc v1.64.0 h1:KH3VH9y/MgNQg1dE7b3XfVK0GsPSIzJwdF617gUSbvY= -google.golang.org/grpc v1.64.0/go.mod h1:oxjF8E3FBnjp+/gVFYdWacaLDx9na1aqy9oovLpxQYg= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf h1:liao9UHurZLtiEwBgT9LMOnKYsHze6eA6w1KQCMVN2Q= +google.golang.org/genproto/googleapis/rpc v0.0.0-20240730163845-b1a4ccb954bf/go.mod h1:Ue6ibwXGpU+dqIcODieyLOcgj7z8+IcskoNIgZxtrFY= +google.golang.org/grpc v1.64.1 h1:LKtvyfbX3UGVPFcGqJ9ItpVWW6oN/2XqTxfAnwRRXiA= +google.golang.org/grpc v1.64.1/go.mod h1:hiQF4LFZelK2WKaP6W0L92zGHtiQdZxk8CrSdvyjeP0= google.golang.org/protobuf v1.34.2 h1:6xV6lTsCfpGD21XK49h7MhtcApnLqkfYgPcdHftf6hg= google.golang.org/protobuf v1.34.2/go.mod h1:qYOHts0dSfpeUzUFpOMr/WGzszTmLH+DiWniOlNbLDw= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= From a279fd225418cc3d0093e447e2a6c0a4c4a96f36 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Fri, 16 Aug 2024 14:09:52 -0400 Subject: [PATCH 12/19] bump go minimum version to 1.22 --- .github/workflows/appsec.yml | 4 ++-- .github/workflows/main-branch-tests.yml | 4 ++-- .github/workflows/pull-request.yml | 2 +- .github/workflows/smoke-tests.yml | 4 ++-- .gitlab/macrobenchmarks.yml | 28 +++++++++++------------ internal/apps/Dockerfile | 2 +- internal/apps/setup-smoke-test/Dockerfile | 2 +- 7 files changed, 23 insertions(+), 23 deletions(-) diff --git a/.github/workflows/appsec.yml b/.github/workflows/appsec.yml index f913f17fdf..76c6b555c8 100644 --- a/.github/workflows/appsec.yml +++ b/.github/workflows/appsec.yml @@ -95,7 +95,7 @@ jobs: strategy: matrix: runs-on: [ macos-12, macos-14 ] # oldest and newest macos runners available - macos-14 mainly is here to cover the fact it is an ARM machine - go-version: [ "1.22", "1.21" ] + go-version: [ "1.22", "1.23" ] fail-fast: true # saving some CI time - macos runners too long to get steps: - uses: actions/checkout@v4 @@ -187,7 +187,7 @@ jobs: needs: go-mod-caching strategy: matrix: - go-version: [ "1.22", "1.21" ] + go-version: [ "1.22", "1.23" ] distribution: [ bookworm, bullseye, alpine ] platform: [ linux/amd64, linux/arm64 ] diff --git a/.github/workflows/main-branch-tests.yml b/.github/workflows/main-branch-tests.yml index 96e4c7ea25..10894ba672 100644 --- a/.github/workflows/main-branch-tests.yml +++ b/.github/workflows/main-branch-tests.yml @@ -22,7 +22,7 @@ jobs: unit-integration-tests: strategy: matrix: - go-version: [ "1.21", "1.22" ] + go-version: [ "1.23", "1.22" ] fail-fast: false uses: ./.github/workflows/unit-integration-tests.yml with: @@ -33,7 +33,7 @@ jobs: strategy: matrix: runs-on: [ macos-latest, windows-latest, ubuntu-latest ] - go-version: [ "1.21", "1.22" ] + go-version: [ "1.23", "1.22" ] fail-fast: false uses: ./.github/workflows/multios-unit-tests.yml with: diff --git a/.github/workflows/pull-request.yml b/.github/workflows/pull-request.yml index 128967216d..9513b2e328 100644 --- a/.github/workflows/pull-request.yml +++ b/.github/workflows/pull-request.yml @@ -18,6 +18,6 @@ jobs: name: PR Unit and Integration Tests uses: ./.github/workflows/unit-integration-tests.yml with: - go-version: "1.21" + go-version: "1.22" ref: ${{ github.ref }} secrets: inherit diff --git a/.github/workflows/smoke-tests.yml b/.github/workflows/smoke-tests.yml index 9bc2c62905..07e316a8e2 100644 --- a/.github/workflows/smoke-tests.yml +++ b/.github/workflows/smoke-tests.yml @@ -76,7 +76,7 @@ jobs: ref: ${{ inputs.ref || github.ref }} - uses: actions/setup-go@v3 with: - go-version: "1.21" + go-version: "1.22" cache: true - name: go mod tidy run: |- @@ -99,7 +99,7 @@ jobs: matrix: # TODO: cross-compilation from/to different hardware architectures once # github provides native ARM runners. - go: [ "1.21", "1.22", "1.23-rc" ] + go: [ "1.22", "1.23" ] build-env: [ alpine, bookworm, bullseye ] build-with-cgo: [ 0, 1 ] deployment-env: [ alpine, debian11, debian12, al2, al2023, busybox, scratch ] diff --git a/.gitlab/macrobenchmarks.yml b/.gitlab/macrobenchmarks.yml index 542bfb0c93..ba625ee23e 100644 --- a/.gitlab/macrobenchmarks.yml +++ b/.gitlab/macrobenchmarks.yml @@ -56,10 +56,10 @@ variables: # 2. Rebuild image in Gitlab CI (build-images CI job in https://gitlab.ddbuild.io/DataDog/apm-reliability/benchmarking-platform/-/pipelines?page=1&scope=all&ref=go%2Fgo-prof-app) # -.go121-benchmarks: +.go123-benchmarks: extends: .benchmarks variables: - GO_VERSION: "1.21.12" + GO_VERSION: "1.23.0" .go122-benchmarks: extends: .benchmarks @@ -123,8 +123,8 @@ go122-profile-trace-asm: ENABLE_APPSEC: "true" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-baseline: - extends: .go121-benchmarks +go123-baseline: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "false" @@ -132,8 +132,8 @@ go121-baseline: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-only-trace: - extends: .go121-benchmarks +go123-only-trace: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -141,8 +141,8 @@ go121-only-trace: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-only-profile: - extends: .go121-benchmarks +go123-only-profile: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "false" @@ -150,8 +150,8 @@ go121-only-profile: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-profile-trace: - extends: .go121-benchmarks +go123-profile-trace: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -159,8 +159,8 @@ go121-profile-trace: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-trace-asm: - extends: .go121-benchmarks +go123-trace-asm: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -168,8 +168,8 @@ go121-trace-asm: ENABLE_APPSEC: "true" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-profile-trace-asm: - extends: .go121-benchmarks +go123-profile-trace-asm: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" diff --git a/internal/apps/Dockerfile b/internal/apps/Dockerfile index 2f32c31648..462dd2080e 100644 --- a/internal/apps/Dockerfile +++ b/internal/apps/Dockerfile @@ -1,4 +1,4 @@ -FROM golang:1.21 +FROM golang:1.22 COPY . /dd-trace-go WORKDIR /dd-trace-go/internal/apps # -t will download all dependencies, including test dependencies diff --git a/internal/apps/setup-smoke-test/Dockerfile b/internal/apps/setup-smoke-test/Dockerfile index 7828ed071a..72b451e8bd 100644 --- a/internal/apps/setup-smoke-test/Dockerfile +++ b/internal/apps/setup-smoke-test/Dockerfile @@ -17,7 +17,7 @@ # select one by default, but also allows to provide a --build-arg option # too instead of relying on the --target option. This way, the CI matrix # can systematically use --build-arg for all of the parameters. -ARG go="1.21" # golang docker image parameter in `golang:{go}-{buildenv}` +ARG go="1.22" # golang docker image parameter in `golang:{go}-{buildenv}` ARG build_env="bookworm" # golang docker image parameter in `golang:{go}-{buildenv}` ARG build_with_cgo="0" # 0 or 1 ARG build_with_vendoring="" # y or empty From 9e135c8e5c77a29b697bcb61237f572924716896 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Tue, 3 Sep 2024 15:12:28 -0400 Subject: [PATCH 13/19] Revert "bump go minimum version to 1.22" This reverts commit a279fd225418cc3d0093e447e2a6c0a4c4a96f36. --- .github/workflows/appsec.yml | 4 ++-- .github/workflows/main-branch-tests.yml | 4 ++-- .github/workflows/pull-request.yml | 2 +- .github/workflows/smoke-tests.yml | 4 ++-- .gitlab/macrobenchmarks.yml | 28 +++++++++++------------ internal/apps/Dockerfile | 2 +- internal/apps/setup-smoke-test/Dockerfile | 2 +- 7 files changed, 23 insertions(+), 23 deletions(-) diff --git a/.github/workflows/appsec.yml b/.github/workflows/appsec.yml index 76c6b555c8..f913f17fdf 100644 --- a/.github/workflows/appsec.yml +++ b/.github/workflows/appsec.yml @@ -95,7 +95,7 @@ jobs: strategy: matrix: runs-on: [ macos-12, macos-14 ] # oldest and newest macos runners available - macos-14 mainly is here to cover the fact it is an ARM machine - go-version: [ "1.22", "1.23" ] + go-version: [ "1.22", "1.21" ] fail-fast: true # saving some CI time - macos runners too long to get steps: - uses: actions/checkout@v4 @@ -187,7 +187,7 @@ jobs: needs: go-mod-caching strategy: matrix: - go-version: [ "1.22", "1.23" ] + go-version: [ "1.22", "1.21" ] distribution: [ bookworm, bullseye, alpine ] platform: [ linux/amd64, linux/arm64 ] diff --git a/.github/workflows/main-branch-tests.yml b/.github/workflows/main-branch-tests.yml index 10894ba672..96e4c7ea25 100644 --- a/.github/workflows/main-branch-tests.yml +++ b/.github/workflows/main-branch-tests.yml @@ -22,7 +22,7 @@ jobs: unit-integration-tests: strategy: matrix: - go-version: [ "1.23", "1.22" ] + go-version: [ "1.21", "1.22" ] fail-fast: false uses: ./.github/workflows/unit-integration-tests.yml with: @@ -33,7 +33,7 @@ jobs: strategy: matrix: runs-on: [ macos-latest, windows-latest, ubuntu-latest ] - go-version: [ "1.23", "1.22" ] + go-version: [ "1.21", "1.22" ] fail-fast: false uses: ./.github/workflows/multios-unit-tests.yml with: diff --git a/.github/workflows/pull-request.yml b/.github/workflows/pull-request.yml index 9513b2e328..128967216d 100644 --- a/.github/workflows/pull-request.yml +++ b/.github/workflows/pull-request.yml @@ -18,6 +18,6 @@ jobs: name: PR Unit and Integration Tests uses: ./.github/workflows/unit-integration-tests.yml with: - go-version: "1.22" + go-version: "1.21" ref: ${{ github.ref }} secrets: inherit diff --git a/.github/workflows/smoke-tests.yml b/.github/workflows/smoke-tests.yml index 07e316a8e2..9bc2c62905 100644 --- a/.github/workflows/smoke-tests.yml +++ b/.github/workflows/smoke-tests.yml @@ -76,7 +76,7 @@ jobs: ref: ${{ inputs.ref || github.ref }} - uses: actions/setup-go@v3 with: - go-version: "1.22" + go-version: "1.21" cache: true - name: go mod tidy run: |- @@ -99,7 +99,7 @@ jobs: matrix: # TODO: cross-compilation from/to different hardware architectures once # github provides native ARM runners. - go: [ "1.22", "1.23" ] + go: [ "1.21", "1.22", "1.23-rc" ] build-env: [ alpine, bookworm, bullseye ] build-with-cgo: [ 0, 1 ] deployment-env: [ alpine, debian11, debian12, al2, al2023, busybox, scratch ] diff --git a/.gitlab/macrobenchmarks.yml b/.gitlab/macrobenchmarks.yml index ba625ee23e..542bfb0c93 100644 --- a/.gitlab/macrobenchmarks.yml +++ b/.gitlab/macrobenchmarks.yml @@ -56,10 +56,10 @@ variables: # 2. Rebuild image in Gitlab CI (build-images CI job in https://gitlab.ddbuild.io/DataDog/apm-reliability/benchmarking-platform/-/pipelines?page=1&scope=all&ref=go%2Fgo-prof-app) # -.go123-benchmarks: +.go121-benchmarks: extends: .benchmarks variables: - GO_VERSION: "1.23.0" + GO_VERSION: "1.21.12" .go122-benchmarks: extends: .benchmarks @@ -123,8 +123,8 @@ go122-profile-trace-asm: ENABLE_APPSEC: "true" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go123-baseline: - extends: .go123-benchmarks +go121-baseline: + extends: .go121-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "false" @@ -132,8 +132,8 @@ go123-baseline: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go123-only-trace: - extends: .go123-benchmarks +go121-only-trace: + extends: .go121-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -141,8 +141,8 @@ go123-only-trace: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go123-only-profile: - extends: .go123-benchmarks +go121-only-profile: + extends: .go121-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "false" @@ -150,8 +150,8 @@ go123-only-profile: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go123-profile-trace: - extends: .go123-benchmarks +go121-profile-trace: + extends: .go121-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -159,8 +159,8 @@ go123-profile-trace: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go123-trace-asm: - extends: .go123-benchmarks +go121-trace-asm: + extends: .go121-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -168,8 +168,8 @@ go123-trace-asm: ENABLE_APPSEC: "true" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go123-profile-trace-asm: - extends: .go123-benchmarks +go121-profile-trace-asm: + extends: .go121-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" diff --git a/internal/apps/Dockerfile b/internal/apps/Dockerfile index 462dd2080e..2f32c31648 100644 --- a/internal/apps/Dockerfile +++ b/internal/apps/Dockerfile @@ -1,4 +1,4 @@ -FROM golang:1.22 +FROM golang:1.21 COPY . /dd-trace-go WORKDIR /dd-trace-go/internal/apps # -t will download all dependencies, including test dependencies diff --git a/internal/apps/setup-smoke-test/Dockerfile b/internal/apps/setup-smoke-test/Dockerfile index 72b451e8bd..7828ed071a 100644 --- a/internal/apps/setup-smoke-test/Dockerfile +++ b/internal/apps/setup-smoke-test/Dockerfile @@ -17,7 +17,7 @@ # select one by default, but also allows to provide a --build-arg option # too instead of relying on the --target option. This way, the CI matrix # can systematically use --build-arg for all of the parameters. -ARG go="1.22" # golang docker image parameter in `golang:{go}-{buildenv}` +ARG go="1.21" # golang docker image parameter in `golang:{go}-{buildenv}` ARG build_env="bookworm" # golang docker image parameter in `golang:{go}-{buildenv}` ARG build_with_cgo="0" # 0 or 1 ARG build_with_vendoring="" # y or empty From 4de2dfdc29c115d24a3432966442e9f8f72998a6 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Tue, 3 Sep 2024 15:14:07 -0400 Subject: [PATCH 14/19] Revert "Revert "bump go minimum version to 1.22"" This reverts commit 9e135c8e5c77a29b697bcb61237f572924716896. --- .github/workflows/appsec.yml | 4 ++-- .github/workflows/main-branch-tests.yml | 4 ++-- .github/workflows/pull-request.yml | 2 +- .github/workflows/smoke-tests.yml | 4 ++-- .gitlab/macrobenchmarks.yml | 28 +++++++++++------------ internal/apps/Dockerfile | 2 +- internal/apps/setup-smoke-test/Dockerfile | 2 +- 7 files changed, 23 insertions(+), 23 deletions(-) diff --git a/.github/workflows/appsec.yml b/.github/workflows/appsec.yml index f913f17fdf..76c6b555c8 100644 --- a/.github/workflows/appsec.yml +++ b/.github/workflows/appsec.yml @@ -95,7 +95,7 @@ jobs: strategy: matrix: runs-on: [ macos-12, macos-14 ] # oldest and newest macos runners available - macos-14 mainly is here to cover the fact it is an ARM machine - go-version: [ "1.22", "1.21" ] + go-version: [ "1.22", "1.23" ] fail-fast: true # saving some CI time - macos runners too long to get steps: - uses: actions/checkout@v4 @@ -187,7 +187,7 @@ jobs: needs: go-mod-caching strategy: matrix: - go-version: [ "1.22", "1.21" ] + go-version: [ "1.22", "1.23" ] distribution: [ bookworm, bullseye, alpine ] platform: [ linux/amd64, linux/arm64 ] diff --git a/.github/workflows/main-branch-tests.yml b/.github/workflows/main-branch-tests.yml index 96e4c7ea25..10894ba672 100644 --- a/.github/workflows/main-branch-tests.yml +++ b/.github/workflows/main-branch-tests.yml @@ -22,7 +22,7 @@ jobs: unit-integration-tests: strategy: matrix: - go-version: [ "1.21", "1.22" ] + go-version: [ "1.23", "1.22" ] fail-fast: false uses: ./.github/workflows/unit-integration-tests.yml with: @@ -33,7 +33,7 @@ jobs: strategy: matrix: runs-on: [ macos-latest, windows-latest, ubuntu-latest ] - go-version: [ "1.21", "1.22" ] + go-version: [ "1.23", "1.22" ] fail-fast: false uses: ./.github/workflows/multios-unit-tests.yml with: diff --git a/.github/workflows/pull-request.yml b/.github/workflows/pull-request.yml index 128967216d..9513b2e328 100644 --- a/.github/workflows/pull-request.yml +++ b/.github/workflows/pull-request.yml @@ -18,6 +18,6 @@ jobs: name: PR Unit and Integration Tests uses: ./.github/workflows/unit-integration-tests.yml with: - go-version: "1.21" + go-version: "1.22" ref: ${{ github.ref }} secrets: inherit diff --git a/.github/workflows/smoke-tests.yml b/.github/workflows/smoke-tests.yml index 9bc2c62905..07e316a8e2 100644 --- a/.github/workflows/smoke-tests.yml +++ b/.github/workflows/smoke-tests.yml @@ -76,7 +76,7 @@ jobs: ref: ${{ inputs.ref || github.ref }} - uses: actions/setup-go@v3 with: - go-version: "1.21" + go-version: "1.22" cache: true - name: go mod tidy run: |- @@ -99,7 +99,7 @@ jobs: matrix: # TODO: cross-compilation from/to different hardware architectures once # github provides native ARM runners. - go: [ "1.21", "1.22", "1.23-rc" ] + go: [ "1.22", "1.23" ] build-env: [ alpine, bookworm, bullseye ] build-with-cgo: [ 0, 1 ] deployment-env: [ alpine, debian11, debian12, al2, al2023, busybox, scratch ] diff --git a/.gitlab/macrobenchmarks.yml b/.gitlab/macrobenchmarks.yml index 542bfb0c93..ba625ee23e 100644 --- a/.gitlab/macrobenchmarks.yml +++ b/.gitlab/macrobenchmarks.yml @@ -56,10 +56,10 @@ variables: # 2. Rebuild image in Gitlab CI (build-images CI job in https://gitlab.ddbuild.io/DataDog/apm-reliability/benchmarking-platform/-/pipelines?page=1&scope=all&ref=go%2Fgo-prof-app) # -.go121-benchmarks: +.go123-benchmarks: extends: .benchmarks variables: - GO_VERSION: "1.21.12" + GO_VERSION: "1.23.0" .go122-benchmarks: extends: .benchmarks @@ -123,8 +123,8 @@ go122-profile-trace-asm: ENABLE_APPSEC: "true" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-baseline: - extends: .go121-benchmarks +go123-baseline: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "false" @@ -132,8 +132,8 @@ go121-baseline: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-only-trace: - extends: .go121-benchmarks +go123-only-trace: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -141,8 +141,8 @@ go121-only-trace: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-only-profile: - extends: .go121-benchmarks +go123-only-profile: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "false" @@ -150,8 +150,8 @@ go121-only-profile: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-profile-trace: - extends: .go121-benchmarks +go123-profile-trace: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -159,8 +159,8 @@ go121-profile-trace: ENABLE_APPSEC: "false" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-trace-asm: - extends: .go121-benchmarks +go123-trace-asm: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" @@ -168,8 +168,8 @@ go121-trace-asm: ENABLE_APPSEC: "true" DD_PROFILING_EXECUTION_TRACE_ENABLED: "false" -go121-profile-trace-asm: - extends: .go121-benchmarks +go123-profile-trace-asm: + extends: .go123-benchmarks variables: ENABLE_DDPROF: "false" ENABLE_TRACING: "true" diff --git a/internal/apps/Dockerfile b/internal/apps/Dockerfile index 2f32c31648..462dd2080e 100644 --- a/internal/apps/Dockerfile +++ b/internal/apps/Dockerfile @@ -1,4 +1,4 @@ -FROM golang:1.21 +FROM golang:1.22 COPY . /dd-trace-go WORKDIR /dd-trace-go/internal/apps # -t will download all dependencies, including test dependencies diff --git a/internal/apps/setup-smoke-test/Dockerfile b/internal/apps/setup-smoke-test/Dockerfile index 7828ed071a..72b451e8bd 100644 --- a/internal/apps/setup-smoke-test/Dockerfile +++ b/internal/apps/setup-smoke-test/Dockerfile @@ -17,7 +17,7 @@ # select one by default, but also allows to provide a --build-arg option # too instead of relying on the --target option. This way, the CI matrix # can systematically use --build-arg for all of the parameters. -ARG go="1.21" # golang docker image parameter in `golang:{go}-{buildenv}` +ARG go="1.22" # golang docker image parameter in `golang:{go}-{buildenv}` ARG build_env="bookworm" # golang docker image parameter in `golang:{go}-{buildenv}` ARG build_with_cgo="0" # 0 or 1 ARG build_with_vendoring="" # y or empty From 50f6db61c7ae9bd1ab72829a3c570c59ebde262c Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Tue, 3 Sep 2024 15:43:45 -0400 Subject: [PATCH 15/19] tidy up a bit --- ddtrace/tracer/span.go | 6 ++---- ddtrace/tracer/stats.go | 2 +- ddtrace/tracer/stats_test.go | 8 ++++---- ddtrace/tracer/tracer_test.go | 2 +- 4 files changed, 8 insertions(+), 10 deletions(-) diff --git a/ddtrace/tracer/span.go b/ddtrace/tracer/span.go index 117577f221..ebfa681fb3 100644 --- a/ddtrace/tracer/span.go +++ b/ddtrace/tracer/span.go @@ -552,10 +552,8 @@ func (s *span) finish(finishTime int64) { return } // we have an active tracer - // todo: no need to check for shouldCompute - if t.config.canComputeStats() && shouldComputeStats(s) { - statSpan, shouldCalc := t.stats.newAggregableSpan(s, t.obfuscator) - log.Info("LETS COMPUTE SOME STATS: should calc %v stat span %v", shouldCalc, s) + if t.config.canComputeStats() { + statSpan, shouldCalc := t.stats.newTracerStatSpan(s, t.obfuscator) if shouldCalc { // the agent supports computed stats select { diff --git a/ddtrace/tracer/stats.go b/ddtrace/tracer/stats.go index 149ac2d5a2..3da0eb0bcc 100644 --- a/ddtrace/tracer/stats.go +++ b/ddtrace/tracer/stats.go @@ -150,7 +150,7 @@ func (c *concentrator) runIngester() { } } -func (c *concentrator) newAggregableSpan(s *span, obfuscator *obfuscate.Obfuscator) (*tracerStatSpan, bool) { +func (c *concentrator) newTracerStatSpan(s *span, obfuscator *obfuscate.Obfuscator) (*tracerStatSpan, bool) { statSpan, ok := c.spanConcentrator.NewStatSpan(s.Service, obfuscatedResource(obfuscator, s.Type, s.Resource), s.Name, s.Type, s.ParentID, s.Start, s.Duration, s.Error, s.Meta, s.Metrics, c.cfg.agent.peerTags) if !ok { diff --git a/ddtrace/tracer/stats_test.go b/ddtrace/tracer/stats_test.go index 6af412ac50..c745d9a138 100644 --- a/ddtrace/tracer/stats_test.go +++ b/ddtrace/tracer/stats_test.go @@ -95,7 +95,7 @@ func TestConcentrator(t *testing.T) { transport := newDummyTransport() c := newConcentrator(&config{transport: transport, env: "someEnv"}, 500_000) assert.Len(t, transport.Stats(), 0) - ss1, ok := c.newAggregableSpan(&s1, nil) + ss1, ok := c.newTracerStatSpan(&s1, nil) assert.True(t, ok) c.Start() c.In <- ss1 @@ -112,9 +112,9 @@ func TestConcentrator(t *testing.T) { transport := newDummyTransport() c := newConcentrator(&config{transport: transport, env: "someEnv"}, (10 * time.Second).Nanoseconds()) assert.Len(t, transport.Stats(), 0) - ss1, ok := c.newAggregableSpan(&s1, nil) + ss1, ok := c.newTracerStatSpan(&s1, nil) assert.True(t, ok) - ss2, ok := c.newAggregableSpan(&s2, nil) + ss2, ok := c.newTracerStatSpan(&s2, nil) assert.True(t, ok) c.Start() c.In <- ss1 @@ -138,7 +138,7 @@ func TestConcentrator(t *testing.T) { transport := newDummyTransport() c := newConcentrator(&config{transport: transport}, 500000) assert.Len(t, transport.Stats(), 0) - ss1, ok := c.newAggregableSpan(&s1, nil) + ss1, ok := c.newTracerStatSpan(&s1, nil) assert.True(t, ok) c.Start() c.In <- ss1 diff --git a/ddtrace/tracer/tracer_test.go b/ddtrace/tracer/tracer_test.go index 99fdf31422..d093ee2784 100644 --- a/ddtrace/tracer/tracer_test.go +++ b/ddtrace/tracer/tracer_test.go @@ -2352,7 +2352,7 @@ loop: Duration: 1, Metrics: map[string]float64{keyMeasured: 1}, } - statSpan, ok := c.newAggregableSpan(s, tr.obfuscator) + statSpan, ok := c.newTracerStatSpan(s, tr.obfuscator) assert.True(t, ok) c.add(statSpan) From 68e056ff8265b127e8f78d27ef7ce3321893ee92 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 4 Sep 2024 14:54:27 -0400 Subject: [PATCH 16/19] more cleanup --- ddtrace/tracer/stats.go | 2 +- ddtrace/tracer/stats_test.go | 38 ------------------------------------ 2 files changed, 1 insertion(+), 39 deletions(-) diff --git a/ddtrace/tracer/stats.go b/ddtrace/tracer/stats.go index 3da0eb0bcc..8bb9462609 100644 --- a/ddtrace/tracer/stats.go +++ b/ddtrace/tracer/stats.go @@ -163,7 +163,7 @@ func (c *concentrator) newTracerStatSpan(s *span, obfuscator *obfuscate.Obfuscat }, true } -// add adds s into the concentrator's internal stats buckets. +// add s into the concentrator's internal stats buckets. func (c *concentrator) add(s *tracerStatSpan) { c.spanConcentrator.AddSpan(s.statSpan, c.aggregationKey, "", nil, s.origin) } diff --git a/ddtrace/tracer/stats_test.go b/ddtrace/tracer/stats_test.go index c745d9a138..63acf92053 100644 --- a/ddtrace/tracer/stats_test.go +++ b/ddtrace/tracer/stats_test.go @@ -52,44 +52,6 @@ func TestConcentrator(t *testing.T) { c.Stop() assert.EqualValues(atomic.LoadUint32(&c.stopped), 1) }) - - //t.Run("valid", func(t *testing.T) { - // c := newConcentrator(&config{env: "someEnv"}, defaultStatsBucketSize) - // //btime := alignTs(ss1.Start+ss1.Duration, defaultStatsBucketSize) - // c.add(ss1) - // - // //assert.Len(t, c.buckets, 1) - // //b, ok := c.buckets[btime] - // //assert.True(t, ok) - // //assert.Equal(t, b.start, uint64(btime)) - // //assert.Equal(t, b.duration, uint64(defaultStatsBucketSize)) - //}) - - //t.Run("grouping", func(t *testing.T) { - // c := newConcentrator(&config{}, defaultStatsBucketSize) - // c.add(ss1) - // c.add(ss1) - // assert.Len(t, c.buckets, 1) - // _, ok := c.buckets[alignTs(ss1.Start+ss1.Duration, defaultStatsBucketSize)] - // assert.True(t, ok) - // c.add(ss2) - // assert.Len(t, c.buckets, 2) - // _, ok = c.buckets[alignTs(ss2.Start+ss2.Duration, defaultStatsBucketSize)] - // assert.True(t, ok) - //}) - // - //t.Run("ingester", func(t *testing.T) { - // transport := newDummyTransport() - // c := newConcentrator(&config{transport: transport}, defaultStatsBucketSize) - // c.Start() - // assert.Len(t, c.buckets, 0) - // c.In <- ss1 - // if !waitForBuckets(c, 1) { - // t.Fatal("sending to channel did not work") - // } - // c.Stop() - //}) - // t.Run("flusher", func(t *testing.T) { t.Run("old", func(t *testing.T) { transport := newDummyTransport() From 1ca882ef13ce71e96ca86e6ab727e75e813d8567 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 4 Sep 2024 15:48:16 -0400 Subject: [PATCH 17/19] copyright job needs go installed --- .github/workflows/unit-integration-tests.yml | 5 ++++- 1 file changed, 4 insertions(+), 1 deletion(-) diff --git a/.github/workflows/unit-integration-tests.yml b/.github/workflows/unit-integration-tests.yml index 0aeca43da9..cc1cf5ad48 100644 --- a/.github/workflows/unit-integration-tests.yml +++ b/.github/workflows/unit-integration-tests.yml @@ -28,7 +28,10 @@ jobs: uses: actions/checkout@v3 with: ref: ${{ inputs.ref || github.ref }} - + - name: Setup Go + uses: ./.github/actions/setup-go + with: + go-version: ${{ inputs.go-version }} - name: Copyright run: | go run checkcopyright.go From bc309731b1833c1858d1b900fa95a78e7d2efff9 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Thu, 5 Sep 2024 09:27:34 -0400 Subject: [PATCH 18/19] no go mod toolchain --- go.mod | 2 -- internal/apps/go.mod | 2 -- 2 files changed, 4 deletions(-) diff --git a/go.mod b/go.mod index 4b996112fb..e0a55a5a1b 100644 --- a/go.mod +++ b/go.mod @@ -2,8 +2,6 @@ module gopkg.in/DataDog/dd-trace-go.v1 go 1.22.0 -toolchain go1.22.5 - require ( cloud.google.com/go/pubsub v1.40.0 github.com/99designs/gqlgen v0.17.36 diff --git a/internal/apps/go.mod b/internal/apps/go.mod index e6b43c7069..8eb353492f 100644 --- a/internal/apps/go.mod +++ b/internal/apps/go.mod @@ -2,8 +2,6 @@ module github.com/DataDog/dd-trace-go/internal/apps go 1.22.0 -toolchain go1.22.5 - require ( golang.org/x/sync v0.8.0 gopkg.in/DataDog/dd-trace-go.v1 v1.64.0 From 2bd641160fe693d92026c06cda8c573d56efd439 Mon Sep 17 00:00:00 2001 From: Andrew Glaude Date: Wed, 23 Oct 2024 11:30:36 -0400 Subject: [PATCH 19/19] ignore seelog goroutine leak --- ddtrace/mocktracer/main_test.go | 6 ++++-- 1 file changed, 4 insertions(+), 2 deletions(-) diff --git a/ddtrace/mocktracer/main_test.go b/ddtrace/mocktracer/main_test.go index d584962bf7..32dc4a16d6 100644 --- a/ddtrace/mocktracer/main_test.go +++ b/ddtrace/mocktracer/main_test.go @@ -6,10 +6,12 @@ package mocktracer import ( - "go.uber.org/goleak" "testing" + + "go.uber.org/goleak" ) func TestMain(m *testing.M) { - goleak.VerifyTestMain(m) + // TODO: seelog (indirect dependency) has a known goroutine leak where it leaks a single goroutine on init (https://github.com/cihub/seelog/issues/182) + goleak.VerifyTestMain(m, goleak.IgnoreAnyFunction("github.com/cihub/seelog.(*asyncLoopLogger).processQueue")) }